query
stringlengths
7
33.1k
document
stringlengths
7
335k
metadata
dict
negatives
listlengths
3
101
negative_scores
listlengths
3
101
document_score
stringlengths
3
10
document_rank
stringclasses
102 values
TransformedDataSource Sometimes you want to calculate a value on a data source that doesn't have an appropriate type. You can wrap the data source with a TransformedDatSource and do back and forth conversions as necessary. The transform needs to use a couple procedures for translating between types.
void example14() { // original data: a bunch of ints IndexedDataSource<SignedInt32Member> list = nom.bdezonia.zorbage.storage.Storage.allocate(G.INT32.construct(), 100); // a procedure to transforms ints to doubles Procedure2<SignedInt32Member,Float64Member> intToDblProc = new Procedure2<SignedInt32Member, Float64Member>() { @Override public void call(SignedInt32Member a, Float64Member b) { b.setV(a.v()); } }; // a procedure to transforms doubles to ints Procedure2<Float64Member,SignedInt32Member> dblToIntProc = new Procedure2<Float64Member,SignedInt32Member>() { @Override public void call(Float64Member a, SignedInt32Member b) { b.setV((int) a.v()); } }; // the definition of the transformed data source IndexedDataSource<Float64Member> xformer = new TransformedDataSource<>(G.INT32, list, intToDblProc, dblToIntProc); // now calculate some results. Notice that Mean can't normally be used on // integer data // not possible: Integers do not have the correct type of division operator // SignedInt32Member resI = G.INT32.construct(); // Mean.compute(G.INT32, list, resI); // with the transformer we can calc mean Float64Member result = G.DBL.construct(); Mean.compute(G.DBL, xformer, result); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "DoubleDataSource apply(DoubleDataSource input, String param);", "private static ValueSource getValueSource(String field, Type type) {\n if (type == Type.BYTE) {\n return new ByteFieldSource(field);\n }\n if (type == Type.SHORT) {\n return new ShortFieldSource(field);\n }\n if (type == Type.INT) {\n return new IntFieldSource(field);\n }\n if (type == Type.FLOAT) {\n return new FloatFieldSource(field);\n }\n throw new IllegalArgumentException(type+\" is not a known Field Score Query Type!\");\n }", "public interface Transformer {\n\t/**\n\t * Transform a source object dynamically.\n\t * \n\t * This iteratively calls {@link #transform(Object, Class) transform}\n\t * \n\t * @param <S>\n\t * the source type.\n\t * @param <T>\n\t * the target type.\n\t * @param source\n\t * The source object.\n\t * @return The target object or <em>null</em> if no applicable rule has been\n\t * found.\n\t * @see #getTransformationRules()\n\t */\n\tpublic <S, T> T transform(S source);\n\n\t/**\n\t * Transform a source object using a specific type of rule.\n\t * \n\t * @param <S>\n\t * the source type.\n\t * @param <T>\n\t * the target type.\n\t * @param source\n\t * The source object.\n\t * @param with\n\t * The type of rule to be used.\n\t * @return The target object or <em>null</em> if no applicable rule has been\n\t * found.\n\t */\n\tpublic <S, T> T transform(S source, Class<? extends Rule<S, T>> with);\n\n\t/**\n\t * Get the list of rule definitions related to this transformation instance.\n\t * \n\t * @return An ordered collection of transformation rule definitions.\n\t */\n\tpublic Set<Class<? extends Rule<?, ?>>> getTransformationRules();\n\n\t/**\n\t * \n\t * @return\n\t */\n\tpublic Context getContext();\n}", "public org.cagrid.data.dcql.DataTransformation getDataTransformation() {\r\n return dataTransformation;\r\n }", "Source updateDatasourceZ3950Timestamp(Source ds) throws RepoxException;", "public interface DataSourceWrapper<D> {\r\n\r\n public void openDataSource() throws Exception;\r\n \r\n public void preValidate() throws Exception;\r\n \r\n public void closeDataSource() throws Exception;\r\n \r\n public void setDataSource(D dataSource);\r\n \r\n public D getDataSource();\r\n \r\n public Iterator<Row> getRowIterator();\r\n \r\n}", "@Override\n\tpublic synchronized Quantity<S> toSource(Quantity<T> target) {\n\t\tfinal Unit<S> acceptableSourceUnits = QuantityFactory.createUnitFromString(getAcceptableSourceUnits().get(0));\n\t\tfinal Unit<T> acceptableTargetUnits = QuantityFactory.createUnitFromString(getAcceptableTargetUnits().get(0));\n\n\t\tif (!target.getUnit().equals(acceptableTargetUnits)) {\n\t\t\tthrow new IllegalArgumentException(\"JEPQuantityConverter.ToSource: target units (\" + target.getUnit()\n\t\t\t\t\t+ \") do not match acceptableUnits (\" + acceptableTargetUnits + \")\" + this.toString());\n\t\t}\n\n\t\tjepTtoS.addVariable(VariableName, target.getValue().doubleValue());\n\t\t// returns in current units doubleValue converts it\n\t\tdouble val = jepTtoS.getValue();\n\t\t// Infinite is a valid value for 1/X when X is 0. so only protect against Nan.\n\t\tif (Double.isNaN(val) /* || Double.isInfinite(val) */) {\n\t\t\tthrow new IllegalArgumentException(\"JEPQuantityConverter.ToSource: Error. Result = \" + val + \" target = \"\n\t\t\t\t\t+ target.getValue().doubleValue() + \" expression = \" + expressionParameters.getExpressionTtoS() + \" \"\n\t\t\t\t\t+ this.toString());\n\t\t}\n\t\treturn QuantityFactory.createFromObject(val, acceptableSourceUnits);\n\t}", "public <S, T> T transform(S source, Class<? extends Rule<S, T>> with);", "DataSet toDataSet(Object adaptee);", "public static org.xms.g.common.api.ResultTransform dynamicCast(java.lang.Object param0) {\n return ((org.xms.g.common.api.ResultTransform) param0);\n }", "T convert(S source) throws ConversionException;", "public void convertFrom(Unit source_unit) throws ArithmeticException {\n\t\tconvert(source_unit, this);\n\t}", "Source createDatasourceZ3950Timestamp(Source ds, Provider prov) throws RepoxException;", "@VTID(12)\n com.exceljava.com4j.excel.XlPivotTableSourceType getSourceType();", "protected abstract Object transform(Object o);", "@Override\n public SourceRecord convert() throws Exception {\n if (record == null) {\n throw new Exception (\"Cannot convert non-existing domain record\");\n }\n if (schema == null) {\n throw new Exception (\"Cannot convert non-existing kafka schema\");\n }\n if (record.getRecordOffset() == null) {\n throw new Exception (\"Cannot convert domain record with no offset\");\n }\n if (mode == null) {\n throw new Exception (\n \"Cannot convert record without connector mode configuration\"\n );\n }\n \n SourceRecord sourceRecord = null;\n \n if (logger.isTraceEnabled()) {\n logger.trace (\"Converting: \" + record.toJSONString());\n }\n \n switch (record.getDomainRecordType()) {\n case CHANGEROW_RECORD:\n {\n if (mode.getCDCFormat() == ConnectorCDCFormat.CHANGEROW) {\n sourceRecord = convertChangeRowRecord (record);\n }\n else {\n throw new Exception (\n \"Invalid configuration, not expecting \" + \n record.getDomainRecordType() + \" records when \" +\n \"configured for CDC format: \" + mode.getCDCFormat()\n );\n }\n break;\n }\n case CHANGESET_RECORD:\n {\n if (mode.getCDCFormat() == ConnectorCDCFormat.CHANGESET) {\n sourceRecord = convertChangeSetRecord (record);\n }\n else {\n throw new Exception (\n \"Invalid configuration, not expecting \" + \n record.getDomainRecordType() + \" records when \" +\n \"configured for CDC format: \" + mode.getCDCFormat()\n );\n } \n break;\n }\n case TRANSACTION_INFO_RECORD:\n {\n if (mode.publishTxInfo()) {\n sourceRecord = convertTransactionDataRecord (record);\n }\n else {\n throw new Exception (\n \"Invalid configuration, not expecting \" + \n record.getDomainRecordType() + \" records when \" +\n \"configured to not publish transaction info \" +\n \"meta data messages\"\n );\n }\n break;\n }\n case METADATA_RECORD:\n case HEADER_RECORD:\n default:\n /* we do not convert these type of records to Kafka records */\n break;\n }\n\n return sourceRecord;\n }", "public FieldTransformer makeFieldTransformer(Object value) {\n throw new RuntimeException(\"makeFieldTransformer(value) not implemented in factory \"\n + this.getClass().toString());\n }", "@Override\n public T getValue() {\n // Returns initial value if source is not set.\n return mLiveDataSource == null ? mInitialValue : mLiveDataSource.getValue();\n }", "public Object convertToCatalyst (Object a, org.apache.spark.sql.catalyst.types.DataType dataType) ;", "public interface DataConverter<JAVATYPE,METATYPE extends FieldDefinition> {\n /** Method invoked for a single JAVATYPE */\n JAVATYPE convert(JAVATYPE oldValue, final METATYPE meta);\n\n /** Method invoked for a JAVATYPE List. This can be used to alter the list length / add / remove elements after processing.\n * Please note that the converter is only invoked on the list itself, not on the individual elements. */\n List <JAVATYPE> convertList(List<JAVATYPE> oldList, final METATYPE meta);\n\n /** Method invoked for a JAVATYPE Set. This can be used to alter the set size / add / remove elements after processing.\n * Please note that the converter is only invoked on the list itself, not on the individual elements. */\n Set <JAVATYPE> convertSet(Set<JAVATYPE> oldSet, final METATYPE meta);\n\n /** Method invoked for an array of JAVATYPEs. This can be used to alter the list length / add / remove elements after processing.\n * Please note that the converter is only invoked on the array itself, not on the individual elements. */\n JAVATYPE [] convertArray(JAVATYPE [] oldArray, final METATYPE meta);\n\n /** Map-type methods. The tree walker converses the value parts of the map only. */\n public <K> Map<K, JAVATYPE> convertMap(Map<K, JAVATYPE> oldMap, final METATYPE meta);\n}", "@Override\n public void mapReduceSource(@Nonnull final Object source, final Object... otherData) {\n if (source instanceof JavaRDD) {\n performSourceMapReduce((JavaRDD) source);\n return;\n }\n if (source instanceof Path) {\n performMapReduce((Path) source);\n return;\n }\n if (source instanceof java.lang.Iterable) {\n performSourceMapReduce(SparkUtilities.fromIterable((Iterable) source));\n return;\n\n }\n throw new IllegalArgumentException(\"cannot handle source of class \" + source.getClass());\n }", "Object transform(String cellValue, Type toValueType) throws Throwable;", "public static Object convert2RowsetCompatible(Object aValue, DataTypeInfo aTypeInfo) throws RowsetException {\n\t\tif (aValue != null) {\n\t\t\tJSTYPE jsType = toJsType(aTypeInfo);\n\t\t\tif (jsType == JSTYPE.UNSUPPORTED) {\n\t\t\t\treturn aValue;\n\t\t\t} else if (jsType == JSTYPE.BOOL) {\n\t\t\t\tif (aValue instanceof Number) {\n\t\t\t\t\treturn ((Number) aValue).intValue() == 1;\n\t\t\t\t} else if (aValue instanceof String) {\n\t\t\t\t\tString s = (String) aValue;\n\t\t\t\t\treturn !s.isEmpty();\n\t\t\t\t} else if (aValue instanceof Boolean) {\n\t\t\t\t\treturn ((Boolean) aValue);\n\t\t\t\t} else if (aValue instanceof Date) {\n\t\t\t\t\treturn !((Date) aValue).equals(new Date(0));\n\t\t\t\t}\n\t\t\t} else if (jsType == JSTYPE.NUMBER) {\n\t\t\t\t// target type - Double\n\t\t\t\tif (aValue instanceof Number) {\n\t\t\t\t\treturn Double.valueOf(((Number) aValue).doubleValue());\n\t\t\t\t} else if (aValue instanceof String) {\n\t\t\t\t\treturn Double.valueOf((String) aValue);\n\t\t\t\t} else if (aValue instanceof Boolean) {\n\t\t\t\t\treturn Double.valueOf(((Boolean) aValue) ? 1 : 0);\n\t\t\t\t} else if (aValue instanceof Date) {\n\t\t\t\t\treturn Double.valueOf(((Date) aValue).getTime());\n\t\t\t\t}\n\t\t\t} else if (jsType == JSTYPE.STRING) {\n\t\t\t\tif (aValue instanceof Number) {\n\t\t\t\t\treturn ((Number) aValue).toString();\n\t\t\t\t} else if (aValue instanceof String) {\n\t\t\t\t\treturn (String) aValue;\n\t\t\t\t} else if (aValue instanceof Boolean) {\n\t\t\t\t\tBoolean b = ((Boolean) aValue);\n\t\t\t\t\treturn Boolean.TRUE.equals(b) ? b.toString() : \"\";\n\t\t\t\t} else if (aValue instanceof Date)\n\t\t\t\t\treturn ((Date) aValue).toString();\n\t\t\t\t// else if (aValue instanceof CompactClob)\n\t\t\t\t// return ((CompactClob)aValue).getData()\n\t\t\t} else if (jsType == JSTYPE.DATE) {\n\t\t\t\tif (aValue instanceof Number) {\n\t\t\t\t\treturn new Date(((Number) aValue).longValue());\n\t\t\t\t} else if (aValue instanceof String) {\n\t\t\t\t\treturn new Date(Long.valueOf((String) aValue));\n\t\t\t\t} else if (aValue instanceof Boolean) {\n\t\t\t\t\treturn new Date(Long.valueOf(((Boolean) aValue) ? 1 : 0));\n\t\t\t\t} else if (aValue instanceof Date) {\n\t\t\t\t\treturn ((Date) aValue);\n\t\t\t\t} else {\n\t\t\t\t\treturn aValue;\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn aValue;\n\t}", "public interface DataTransformation {\n /**\n * Provide a data transformation on the supplied feed data. The type of processing is arbitrary and based on the context\n * in which the method is invoked.\n * @param data for the parameters in the given time range\n * @param startTime for the data request, this may not correspond to any times in the data set.\n * @param endTime for the data request, this may not correspond to any times in the data set.\n */\n void transform(Map<String, List<Map<String,String>>> data, long startTime, long endTime);\n }", "@Override\n \tpublic void transformExistingGraph(TransformedGraph inputGraph,\n \t\t\tTransformationContext context) throws TransformerException {\n \t\tthis.context = context;\n \n \t\ttry\n \t\t{\n \t\t\tDouble outdatedScore = getGraphScore(inputGraph.getGraphName(), inputGraph.getMetadataGraphName(), getCleanConnection());\n \t\t\tDouble updatedScore = getGraphScore(inputGraph.getGraphName(), inputGraph.getMetadataGraphName(), getDirtyConnection());\n \n \t\t\tupdatePublisherScore(inputGraph.getGraphName(),\n \t\t\t\t\tinputGraph.getMetadataGraphName(),\n \t\t\t\t\tupdatedScore - outdatedScore,\n \t\t\t\t\t0);\n \t\t} catch (QualityAssessmentException e) {\n \t\t\tthrow new TransformerException(e);\n \t\t} catch (DatabaseException e) {\n \t\t\tthrow new TransformerException(e);\n \t\t} finally {\n \t\t\tcloseCleanConnection();\n \t\t\tcloseDirtyConnection();\n \t\t}\n \t}", "IStreamList<T> transform(IStreamList<T> dataset);", "T convert(F experimenterMessageCase, D data) throws ConversionException;", "public void setDataTransformation(org.cagrid.data.dcql.DataTransformation dataTransformation) {\r\n this.dataTransformation = dataTransformation;\r\n }", "public Object enterTransform(Object value) {\n return value;\n }", "@Override\n \tpublic void transformNewGraph(TransformedGraph inputGraph,\n \t\t\tTransformationContext context) throws TransformerException {\n \t\tthis.context = context;\n \n \t\ttry\n \t\t{\n \t\t\tDouble newScore = getGraphScore(inputGraph.getGraphName(), inputGraph.getMetadataGraphName(), getDirtyConnection());\n \n \t\t\tupdatePublisherScore(inputGraph.getGraphName(),\n \t\t\t\t\tinputGraph.getMetadataGraphName(),\n \t\t\t\t\tnewScore,\n \t\t\t\t\t1);\n \t\t} catch (QualityAssessmentException e) {\n \t\t\tthrow new TransformerException(e);\n \t\t} catch (DatabaseException e) {\n \t\t\tthrow new TransformerException(e);\n \t\t} finally {\n \t\t\tcloseCleanConnection();\n \t\t\tcloseDirtyConnection();\n \t\t}\n \t}", "public interface TypeDataConverter<T> {\n public Integer getInteger(T source, String columnName, Integer defaultValue);\n public Long getLong(T source, String columnName, Long defaultValue);\n public Double getDouble(T source, String columnName, Double defaultValue);\n public String getString(T source, String columnName, String defaultValue);\n}", "@Override\n\tpublic synchronized Quantity<T> toTarget(Quantity<S> source) {\n\t\tfinal Unit<S> acceptableSourceUnits = QuantityFactory.createUnitFromString(getAcceptableSourceUnits().get(0));\n\t\tfinal Unit<T> acceptableTargetUnits = QuantityFactory.createUnitFromString(getAcceptableTargetUnits().get(0));\n\n\t\tif (!source.getUnit().equals(acceptableSourceUnits)) {\n\t\t\tthrow new IllegalArgumentException(\"JEPQuantityConverter.ToTarget: source units (\" + source.getUnit()\n\t\t\t\t\t+ \") do not match acceptableUnits (\" + acceptableSourceUnits + \") \" + this.toString());\n\t\t}\n\n\t\tjepStoT.addVariable(VariableName, source.getValue().doubleValue());\n\t\tdouble val = jepStoT.getValue();\n\t\t// Infinite is a valid value for 1/X when X is 0. so only protect against Nan.\n\t\tif (Double.isNaN(val) /* || Double.isInfinite(val) */) {\n\t\t\tthrow new IllegalArgumentException(\"JEPQuantityConverter.ToTarget: Error. Result = \" + val + \" source = \"\n\t\t\t\t\t+ source.getValue().doubleValue() + \" expression = \" + expressionParameters.getExpressionStoT() + \" \"\n\t\t\t\t\t+ this.toString());\n\t\t}\n\t\treturn QuantityFactory.createFromObject(val, acceptableTargetUnits);\n\t}", "public abstract ResolvedType transformTypeParameters(ResolvedTypeTransformer transformer);", "public static HiveObjectConversion getConversion(\n ObjectInspector inspector, LogicalType dataType, HiveShim hiveShim) {\n if (inspector instanceof PrimitiveObjectInspector) {\n HiveObjectConversion conversion;\n if (inspector instanceof BooleanObjectInspector\n || inspector instanceof StringObjectInspector\n || inspector instanceof ByteObjectInspector\n || inspector instanceof ShortObjectInspector\n || inspector instanceof IntObjectInspector\n || inspector instanceof LongObjectInspector\n || inspector instanceof FloatObjectInspector\n || inspector instanceof DoubleObjectInspector\n || inspector instanceof BinaryObjectInspector\n || inspector instanceof VoidObjectInspector) {\n conversion = IdentityConversion.INSTANCE;\n } else if (inspector instanceof DateObjectInspector) {\n conversion = hiveShim::toHiveDate;\n } else if (inspector instanceof TimestampObjectInspector) {\n conversion = hiveShim::toHiveTimestamp;\n } else if (inspector instanceof HiveCharObjectInspector) {\n conversion =\n o ->\n o == null\n ? null\n : new HiveChar(\n (String) o, ((CharType) dataType).getLength());\n } else if (inspector instanceof HiveVarcharObjectInspector) {\n conversion =\n o ->\n o == null\n ? null\n : new HiveVarchar(\n (String) o, ((VarCharType) dataType).getLength());\n } else if (inspector instanceof HiveDecimalObjectInspector) {\n conversion = o -> o == null ? null : HiveDecimal.create((BigDecimal) o);\n } else if (inspector instanceof HiveIntervalYearMonthObjectInspector) {\n conversion =\n o -> {\n if (o == null) {\n return null;\n } else {\n Period period = (Period) o;\n return new HiveIntervalYearMonth(\n period.getYears(), period.getMonths());\n }\n };\n } else if (inspector instanceof HiveIntervalDayTimeObjectInspector) {\n conversion =\n o -> {\n if (o == null) {\n return null;\n } else {\n Duration duration = (Duration) o;\n return new HiveIntervalDayTime(\n duration.getSeconds(), duration.getNano());\n }\n };\n } else {\n throw new FlinkHiveUDFException(\n \"Unsupported primitive object inspector \" + inspector.getClass().getName());\n }\n // if the object inspector prefers Writable objects, we should add an extra conversion\n // for that\n // currently this happens for constant arguments for UDFs\n if (((PrimitiveObjectInspector) inspector).preferWritable()) {\n conversion = new WritableHiveObjectConversion(conversion, hiveShim);\n }\n return conversion;\n }\n\n if (inspector instanceof ListObjectInspector) {\n HiveObjectConversion eleConvert =\n getConversion(\n ((ListObjectInspector) inspector).getListElementObjectInspector(),\n ((ArrayType) dataType).getElementType(),\n hiveShim);\n return o -> {\n if (o == null) {\n return null;\n }\n Object[] array = (Object[]) o;\n List<Object> result = new ArrayList<>();\n\n for (Object ele : array) {\n result.add(eleConvert.toHiveObject(ele));\n }\n return result;\n };\n }\n\n if (inspector instanceof MapObjectInspector) {\n MapObjectInspector mapInspector = (MapObjectInspector) inspector;\n MapType kvType = (MapType) dataType;\n\n HiveObjectConversion keyConversion =\n getConversion(\n mapInspector.getMapKeyObjectInspector(), kvType.getKeyType(), hiveShim);\n HiveObjectConversion valueConversion =\n getConversion(\n mapInspector.getMapValueObjectInspector(),\n kvType.getValueType(),\n hiveShim);\n\n return o -> {\n if (o == null) {\n return null;\n }\n Map<Object, Object> map = (Map) o;\n Map<Object, Object> result = CollectionUtil.newHashMapWithExpectedSize(map.size());\n\n for (Map.Entry<Object, Object> entry : map.entrySet()) {\n result.put(\n keyConversion.toHiveObject(entry.getKey()),\n valueConversion.toHiveObject(entry.getValue()));\n }\n return result;\n };\n }\n\n if (inspector instanceof StructObjectInspector) {\n StructObjectInspector structInspector = (StructObjectInspector) inspector;\n\n List<? extends StructField> structFields = structInspector.getAllStructFieldRefs();\n\n List<RowType.RowField> rowFields = ((RowType) dataType).getFields();\n\n HiveObjectConversion[] conversions = new HiveObjectConversion[structFields.size()];\n for (int i = 0; i < structFields.size(); i++) {\n conversions[i] =\n getConversion(\n structFields.get(i).getFieldObjectInspector(),\n rowFields.get(i).getType(),\n hiveShim);\n }\n\n return o -> {\n if (o == null) {\n return null;\n }\n Row row = (Row) o;\n List<Object> result = new ArrayList<>(row.getArity());\n for (int i = 0; i < row.getArity(); i++) {\n result.add(conversions[i].toHiveObject(row.getField(i)));\n }\n return result;\n };\n }\n\n throw new FlinkHiveUDFException(\n String.format(\n \"Flink doesn't support convert object conversion for %s yet\", inspector));\n }", "@Override\n\tpublic Timestamp convert(Date source) {\n\t\treturn new Timestamp(source.getTime());\n\t}", "Object translate( Object source );", "public interface ValueConvertor {\n\t/**\n\t * \n\t * Convert the value of result set to JAVA type<BR>\n\t * \n\t * @param cursor\n\t * @param columnIndex\n\t * @param javaType\n\t * @return value after converting\n\t */\n\tObject convertCursorToJavaValue(Cursor cursor, int columnIndex,\n\t\t\tClass<?> javaType);\n\n\t/**\n\t * \n\t * Convert DB type to JAVA type<BR>\n\t * \n\t * @param value\n\t * @param javaType\n\t * @return value after converting\n\t */\n\tObject convertDBValueToJavaValue(Object value, Class<?> javaType);\n\n\t/**\n\t * Convert JAVA type to DB type<BR>\n\t * \n\t * @param value\n\t * @param javaType\n\t * @return value after converting\n\t */\n\tObject convertJavaValueToDBValue(Object value, Class<?> javaType);\n}", "@Test\r\n\tvoid testDataSourceConversions() {\r\n\t\tDeconstructor underTest = sampleDataSource.deconstructor();\r\n\t\r\n\t\tassertArrayEquals(stringData.getBytes(StandardCharsets.UTF_8), underTest.getByteArrayByName(STRING_DS_NAME).get());\r\n\t\tassertEquals(byteArrayDataStr, underTest.getStringByName(BYTE_ARRAY_DS_NAME).get());\r\n\t}", "protected ResultTransformer resolveResultTransformer(ResultTransformer resultTransformer) {\n \t\treturn resultTransformer;\n \t}", "public abstract T getSource();", "Target convert(Source source);", "@Data\npublic class <XXX>ModelInfo extends AbstractModelInfo {\n private <Field1DataType> <Field1>;\n /**\n * @return an corresponding {@link <XXX>Transformer} for this model info\n */\n @Override\n public Transformer getTransformer() {\n return new <XXX>Transformer(this);\n }", "@SuppressWarnings(\"unchecked\")\n\tpublic static <T> T convertData(Data data, Class<T> targetClass) {\n\t\tif (data.getType().getName().equals(\"string\")) {\n\t\t\tString string;\n\t\t\ttry {\n\t\t\t\tstring = new DataInputStream(data.getValue()).readUTF();\n\t\t\t} catch (IOException e) {\n\t\t\t\tthrow new RuntimeException(\"Fix this IOException passing\", e);\n\t\t\t}\n\t\t\tif (targetClass.equals(String.class)) {\n\t\t\t\treturn (T) string;\n\t\t\t} else if (targetClass.equals(Integer.class) || targetClass.equals(Integer.TYPE)) {\n\t\t\t\treturn (T) Integer.valueOf(string);\n\t\t\t} else if (targetClass.equals(Double.class) || targetClass.equals(Double.TYPE)) {\n\t\t\t\treturn (T) Double.valueOf(string);\n\t\t\t}\n\t\t} else if (data.getType().getName().equals(\"int32\")) {\n\t\t\tint integer;\n\t\t\ttry {\n\t\t\t\tinteger = new DataInputStream(data.getValue()).readInt();\n\t\t\t} catch (IOException e) {\n\t\t\t\tthrow new RuntimeException(\"Fix this IOException passing\", e);\n\t\t\t}\n\t\t\tif (targetClass.equals(String.class)) {\n\t\t\t\treturn (T) String.valueOf(integer);\n\t\t\t} else if (targetClass.equals(Integer.class) || targetClass.equals(Integer.TYPE)) {\n\t\t\t\treturn (T) Integer.valueOf(integer);\n\t\t\t} else if (targetClass.equals(Double.class) || targetClass.equals(Double.TYPE)) {\n\t\t\t\treturn (T) Double.valueOf(integer);\n\t\t\t}\n\t\t}\n\t\tthrow new RuntimeException(\"Conversion for \" + data.getType().getName() + \" to \" + targetClass\n\t\t\t\t+ \" not implemented yet\");\n\t}", "private static Object parseData(String source, Class<?> expectedType){\n\t\tif(expectedType.equals(Integer.class)) return new Integer(source);\n\t\tif(expectedType.equals(Boolean.class)) return new Boolean(source);\n\t\tif(expectedType.equals(Double.class)) return new Double(source);\n\t\treturn source;\n\t}", "private static Number transform(Object value) {\n\t\tif (value == null) {\n\t\t\treturn Integer.valueOf(0);\n\t\t}\n\t\tif (value instanceof String) {\n\t\t\ttry {\n\t\t\t\treturn Integer.parseInt((String)value);\n\t\t\t} catch(NumberFormatException ex) {\n\t\t\t\ttry {\n\t\t\t\t\treturn Double.parseDouble((String)value);\n\t\t\t\t} catch (NumberFormatException ex2) {\n\t\t\t\t\tthrow new RuntimeException(\n\t\t\t\t\t\t\t\"String \" + value + \" cannot be interpreted as a number\");\n\t\t\t\t}\n\t\t\t}\n\t\t} else if (!(value instanceof Double || value instanceof Integer)) {\n\t\t\tthrow new RuntimeException(value.toString() + \" cannot be interpreted as a number.\");\n\t\t}\n\t\treturn (Number)value;\n\t}", "public interface Object_To_Target<T> extends IsTransformer<Object, T> {\r\n\r\n\t/**\r\n\t * Returns the class for of the target type.\r\n\t * @return target type class, should not be `null`\r\n\t */\r\n\tClass<T> getClazzT();\r\n\r\n\t/**\r\n\t * Returns the null value for the transformation, used if a null test succeeds\r\n\t * @return null value, can be `null` (then `null` is the null value)\r\n\t */\r\n\tT getNullValue();\r\n\r\n\t/**\r\n\t * Returns the false value for the transformation, used in case no test succeeds.\r\n\t * @return false value, can be `null` (then `null` is the false value)\r\n\t */\r\n\tT getFalseValue();\r\n\r\n\t/**\r\n\t * Returns a flag that say if, when the transform object is a collection, only the first non-null element should be used as return value.\r\n\t * @return use collection first element only flag, defaults to `false`\r\n\t */\r\n\tboolean getCollFirstFlag();\r\n\r\n\t/**\r\n\t * Type safe transformation from Object to target class, with optional special processing for `Object[]` and `Collection`.\r\n\t * The conversion is done in the following sequence:\r\n\t * \r\n\t * * If value is `null`, the `nullValue` will be returned.\r\n\t * * If the requested class is an object array ({@link #getClazzT()}==Object[]),\r\n\t * then the return is `value` (if value is an `Object[]`)\r\n\t * or `Collection.toArray()` (if value is a `Collection)`.\r\n\t * In all other cases the process proceeds\r\n\t * * If `collFist` is set to `true` and value is a `Collection`, the first value of this collection will be used for the further process\r\n\t * * Now another `null` test returning `nullValue` if value is `null`\r\n\t * * Next test if the {@link #getClazzT()} is an instance of `value.class`. If true, `value` will be returned\r\n\t * * Next try for some standard type conversions for `value`, namely\r\n\t * ** If {@link #getClazzT()} is an instance of `Boolean` and value is `true` or `on` (case insensitive), then return `Boolean(true)`\r\n\t * ** If {@link #getClazzT()} is an instance of `Boolean` and value is `false` or `off` (case insensitive), then return `Boolean(false)`\r\n\t * ** If {@link #getClazzT()} is an instance of `Integer` then try to return `Integer.valueOf(value.toString)`\r\n\t * ** If {@link #getClazzT()} is an instance of `Double` then try to return `Double.valueOf(value.toString)`\r\n\t * ** If {@link #getClazzT()} is an instance of `Long` then try to return `Long.valueOf(value.toString)`\r\n\t * * The last option is to return `valueFalse` to indicate that no test was successful\r\n\t * \r\n\t * This method does suppress warnings for \"`unchecked`\" castings, because a casting from any concrete return type to `T` is unsafe.\r\n\t * Because all actual castings follow an explicit type check, this suppression should have not negative impact (i.e. there are no {@link ClassCastException}).\r\n\t * \r\n\t * @param obj input object for conversion\r\n\t * @return a value of type `T` if a conversion was successful, `nullValue` if `null` was tested successfully, `falseValue` in all other cases\r\n\t */\r\n\t@SuppressWarnings(\"unchecked\")\r\n\t@Override\r\n\tdefault T transform(Object obj) {\r\n\t\tif(obj==null){\r\n\t\t\treturn this.getNullValue();\r\n\t\t}\r\n\r\n\t\t//next check for Object[], because here we want collections unchanged\r\n\t\tif(this.getClazzT().isInstance(new Object[]{})){\r\n\t\t\tif(obj instanceof Object[]){\r\n\t\t\t\treturn (T)obj;\r\n\t\t\t}\r\n\t\t\telse if(obj instanceof Collection){\r\n\t\t\t\treturn (T)((Collection<?>)obj).toArray();\r\n\t\t\t}\r\n\t\t}\r\n\r\n\t\t//now, if collection use the first value\r\n\t\tif(this.getCollFirstFlag()==true && ClassUtils.isAssignable(obj.getClass(), Collection.class)){\r\n\t\t\tCollection_To_FirstElement<Object> tr = Collection_To_FirstElement.create();\r\n\t\t\tobj = tr.transform((Collection<Object>)obj);\r\n\t\t}\r\n\r\n\t\t//check value again, this maybe the one from the collection\r\n\t\tif(obj==null){\r\n\t\t\treturn this.getNullValue();\r\n\t\t}\r\n\r\n\t\t//if value is T, return caste to T\r\n\t\tif(this.getClazzT().isInstance(obj)){\r\n\t\t\treturn (T)obj;\r\n\t\t}\r\n\r\n\t\tif(this.getClazzT().isInstance(new Boolean(true))){\r\n\t\t\tObject ret = String_To_Boolean.create().transform(obj.toString());\r\n\t\t\tif(ret!=null){\r\n\t\t\t\treturn (T) ret;\r\n\t\t\t}\r\n\t\t}\r\n\t\tif(this.getClazzT().isInstance(new Integer(0))){\r\n\t\t\ttry{\r\n\t\t\t\treturn (T)Integer.valueOf(obj.toString());\r\n\t\t\t}\r\n\t\t\tcatch(Exception ignore){}\r\n\t\t}\r\n\t\tif(this.getClazzT().isInstance(new Double(0))){\r\n\t\t\ttry{\r\n\t\t\t\treturn (T)Double.valueOf(obj.toString());\r\n\t\t\t}\r\n\t\t\tcatch(Exception ignore){}\r\n\t\t}\r\n\t\tif(this.getClazzT().isInstance(new Long(0))){\r\n\t\t\ttry{\r\n\t\t\t\treturn (T)Long.valueOf(obj.toString());\r\n\t\t\t}\r\n\t\t\tcatch(Exception ignore){}\r\n\t\t}\r\n\r\n\t\t//no other option, return falseValue\r\n\t\treturn this.getFalseValue();\r\n\t}\r\n\r\n\t/**\r\n\t * Creates a transformer that takes an Object and returns a target type.\r\n\t * @param <T> target type for the transformation\r\n\t * @param clazz the requested type of the return value, required for initialization\r\n\t * @param nullValue the value to be used if a null test succeeds\r\n\t * @param falseValue the value to be used in case no test succeeds\r\n\t * @param collFirst if set true, collections will be processed and the first element returned, no special collection processing otherwise\r\n\t * @return new transformer that returns a value of type `T` if a conversion was successful, `nullValue` if `null` was tested successfully, `falseValue` in all other cases\r\n\t */\r\n\tstatic <T> Object_To_Target<T> create(final Class<T> clazz, final T nullValue, final T falseValue, final boolean collFirst){\r\n\t\treturn new Object_To_Target<T>() {\r\n\t\t\t@Override\r\n\t\t\tpublic Class<T> getClazzT() {\r\n\t\t\t\treturn clazz;\r\n\t\t\t}\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic T getNullValue() {\r\n\t\t\t\treturn nullValue;\r\n\t\t\t}\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic T getFalseValue() {\r\n\t\t\t\treturn falseValue;\r\n\t\t\t}\r\n\r\n\t\t\t@Override\r\n\t\t\tpublic boolean getCollFirstFlag() {\r\n\t\t\t\treturn collFirst;\r\n\t\t\t}};\r\n\t}\r\n\r\n\t/**\r\n\t * Type safe casting or conversion from Object to target class, special processing for Object[] and Collections.\r\n\t * This is a convenient method for {@link #convert(Object, Class, Object, Object, boolean)} with both return values set to null and\r\n\t * the last argument set to true (i.e. special processing of collections).\r\n\t * @see #convert(Object, Class, Object, Object, boolean)\r\n\t * @param <T> type of the return object\r\n\t * @param value the value that should be converted\r\n\t * @param clazz the requested type of the return value, needed for initialization\r\n\t * @return a value of type `T` if a conversion was successful, `nullValue` if `null` was tested successfully, `falseValue` in all other cases\r\n\t */\r\n\tstatic <T> T convert(Object value, Class<T> clazz){\r\n\t\treturn Object_To_Target.convert(value, clazz, null, null, true);\r\n\t}\r\n\r\n\t/**\r\n\t * Type safe casting or conversion from Object to target class, special processing for Object[] and Collections.\r\n\t * This is a convenient method for {@link #convert(Object, Class, Object, Object, boolean)} with the last \r\n\t * argument set to true (i.e. special processing of collections).\r\n\t * @see #convert(Object, Class, Object, Object, boolean)\r\n\t * @param <T> type of the return object\r\n\t * @param value the value that should be converted\r\n\t * @param clazz the requested type of the return value, needed for initialization\r\n\t * @param nullValue the value to be used if a null test succeeds\r\n\t * @param falseValue the value to be used in case no test succeeds\r\n\t * @return a value of type `T` if a conversion was successful, `nullValue` if `null` was tested successfully, `falseValue` in all other cases\r\n\t */\r\n\tstatic <T> T convert(Object value, Class<T> clazz, T nullValue, T falseValue){\r\n\t\treturn Object_To_Target.convert(value, clazz, nullValue, falseValue, true);\r\n\t}\r\n\r\n\t/**\r\n\t * Type safe casting or conversion from Object to target class, with optional special processing for Object[] and Collections.\r\n\t * @see #create\r\n\t * @param <T> type of the return object\r\n\t * @param value the value that should be converted\r\n\t * @param clazz the requested type of the return value, needed for initialization\r\n\t * @param nullValue the value to be used if a null test succeeds\r\n\t * @param falseValue the value to be used in case no test succeeds\r\n\t * @param collFirst if set true, collections will be processed and the first element returned, no special collection processing otherwise\r\n\t * @return a value of type `T` if a conversion was successful, `nullValue` if `null` was tested successfully, `falseValue` in all other cases\r\n\t */\r\n\tstatic <T> T convert(Object value, Class<T> clazz, T nullValue, T falseValue, boolean collFirst){\r\n\t\treturn Object_To_Target.create(clazz, nullValue, falseValue, collFirst).transform(value);\r\n\t}\r\n}", "Type getSource();", "public String getADataSourceValue() {\r\n return aDataSourceValue;\r\n }", "@Override\n String produce(DBO object) throws TransformerException;", "public double castToDoubleValue() {\n throw new IteratorFlowException(\"Cannot call castToDouble on non numeric\");\n }", "public synchronized final void process() throws FilterException {\n if (this.result == null)\n throw new FilterException(i18n.getString(\"outputNotSet\"));\n if (this.source == null)\n throw new FilterException(i18n.getString(\"inputNotSet\"));\n\n try {\n // Starts the input interpretation (transformation)\n this.transformer.transform(this.source, this.result);\n } catch (TransformerException e) {\n throw new FilterException(e);\n } finally {\n this.source = null;\n this.result = null;\n }\n }", "public abstract Double getDataValue();", "public abstract void transformReportEntry(ReportRow entry);", "private void deNormalise(RowMetaInterface rowMeta, Object[] rowData) throws KettleValueException\n\t{\n\t\tValueMetaInterface valueMeta = rowMeta.getValueMeta(data.keyFieldNr);\n\t\tObject valueData = rowData[data.keyFieldNr];\n\t\tString key = valueMeta.getCompatibleString(valueData);\n if ( !Const.isEmpty(key) )\n {\n // Get all the indexes for the given key value...\n \t// \n List<Integer> indexes = data.keyValue.get(key);\n if (indexes!=null) // otherwise we're not interested.\n {\n for (int i=0;i<indexes.size();i++)\n {\n Integer keyNr = indexes.get(i);\n if (keyNr!=null)\n {\n // keyNr is the field in DenormaliserTargetField[]\n //\n int idx = keyNr.intValue();\n DenormaliserTargetField field = meta.getDenormaliserTargetField()[idx];\n \n // This is the value we need to de-normalise, convert, aggregate.\n //\n ValueMetaInterface sourceMeta = rowMeta.getValueMeta(data.fieldNameIndex[idx]);\n Object sourceData = rowData[data.fieldNameIndex[idx]];\n Object targetData;\n // What is the target value metadata??\n // \n ValueMetaInterface targetMeta = data.outputRowMeta.getValueMeta(data.inputRowMeta.size()-data.removeNrs.length+idx);\n // What was the previous target in the result row?\n //\n Object prevTargetData = data.targetResult[idx];\n \n switch(field.getTargetAggregationType())\n {\n case DenormaliserTargetField.TYPE_AGGR_SUM:\n targetData = targetMeta.convertData(sourceMeta, sourceData);\n \tif (prevTargetData!=null)\n \t{\n \t\tprevTargetData = ValueDataUtil.plus(targetMeta, prevTargetData, targetMeta, targetData);\n \t}\n \telse\n \t{\n \t\tprevTargetData = targetData;\n \t}\n break;\n case DenormaliserTargetField.TYPE_AGGR_MIN:\n if (sourceMeta.compare(sourceData, targetMeta, prevTargetData)<0) {\n \tprevTargetData = targetMeta.convertData(sourceMeta, sourceData);\n }\n break;\n case DenormaliserTargetField.TYPE_AGGR_MAX:\n if (sourceMeta.compare(sourceData, targetMeta, prevTargetData)>0) {\n \tprevTargetData = targetMeta.convertData(sourceMeta, sourceData);\n }\n break;\n case DenormaliserTargetField.TYPE_AGGR_COUNT_ALL:\n prevTargetData = ++data.counters[idx];\n break;\n case DenormaliserTargetField.TYPE_AGGR_AVERAGE:\n targetData = targetMeta.convertData(sourceMeta, sourceData);\n if (!sourceMeta.isNull(sourceData)) \n {\n prevTargetData = data.counters[idx]++;\n if (data.sum[idx]==null)\n {\n \tdata.sum[idx] = targetData;\n }\n else\n {\n \tdata.sum[idx] = ValueDataUtil.plus(targetMeta, data.sum[idx], targetMeta, targetData);\n }\n // data.sum[idx] = (Integer)data.sum[idx] + (Integer)sourceData;\n }\n break;\n case DenormaliserTargetField.TYPE_AGGR_CONCAT_COMMA:\n String separator=\",\";\n\n targetData = targetMeta.convertData(sourceMeta, sourceData);\n if (prevTargetData!=null)\n {\n prevTargetData = prevTargetData+separator+targetData;\n }\n else\n {\n prevTargetData = targetData;\n }\n break;\n case DenormaliserTargetField.TYPE_AGGR_NONE:\n default:\n targetData = targetMeta.convertData(sourceMeta, sourceData);\n prevTargetData = targetMeta.convertData(sourceMeta, sourceData); // Overwrite the previous\n break;\n }\n \n // Update the result row too\n //\n data.targetResult[idx] = prevTargetData;\n }\n }\n }\n }\n\t}", "@java.lang.Override\n public godot.wire.Wire.Transform getTransformValue() {\n if (transformValueBuilder_ == null) {\n if (typeCase_ == 14) {\n return (godot.wire.Wire.Transform) type_;\n }\n return godot.wire.Wire.Transform.getDefaultInstance();\n } else {\n if (typeCase_ == 14) {\n return transformValueBuilder_.getMessage();\n }\n return godot.wire.Wire.Transform.getDefaultInstance();\n }\n }", "@SuppressWarnings({ \"unchecked\", \"rawtypes\" })\r\n\tpublic <T> T parseResult(Record record, Class<T> resultType, ConversionService conversionService, PersistenceExecutionContext persistenceExecutionContext) throws IllegalAccessException, InstantiationException, InvocationTargetException, NoSuchMethodException\r\n\t{\r\n\t\tif(isSingleFieldReturn)\r\n\t\t{\r\n\t\t\tResultField resField = this.resultFields.get(0);\r\n\t\t\tObject res = conversionService.convertToJavaType(record.getObject(resField.code), resField.fieldDetails);\r\n\r\n\t\t\treturn (T) ConvertUtils.convert(res, resField.fieldType);\r\n\t\t}\r\n\r\n\t\tT result = resultType.newInstance();\r\n\t\tObject value = null;\r\n\t\tForeignConstraintDetails foreignConstraint = null;\r\n\t\tEntityDetails foreignEntityDetails = null;\r\n\r\n\t\tRepositoryFactory repositoryFactory = persistenceExecutionContext.getRepositoryFactory();\r\n\t\t\r\n\t\tboolean isEntityResultType = (resultType.getAnnotation(Table.class) != null);\r\n\r\n\t\tfor(ResultField resultField : this.resultFields)\r\n\t\t{\r\n\t\t\tvalue = record.getObject(resultField.code);\r\n\r\n\t\t\t// ignore null values\r\n\t\t\tif(value == null)\r\n\t\t\t{\r\n\t\t\t\tcontinue;\r\n\t\t\t}\r\n\r\n\t\t\ttry\r\n\t\t\t{\r\n\t\t\t\t// as only table owned properties are maintained under\r\n\t\t\t\t// returnColumnToField\r\n\t\t\t\t// this would be parent (target entity) that needs to be loaded\r\n\t\t\t\tif(resultField.fieldDetails.isRelationField())\r\n\t\t\t\t{\r\n\t\t\t\t\tforeignConstraint = resultField.fieldDetails.getForeignConstraintDetails();\r\n\t\t\t\t\tforeignEntityDetails = foreignConstraint.getTargetEntityDetails();\r\n\r\n\t\t\t\t\tvalue = ProxyEntityCreator.newProxyById(foreignEntityDetails, repositoryFactory.getRepositoryForEntity((Class) foreignEntityDetails.getEntityType()), value);\r\n\t\t\t\t}\r\n\t\t\t\t//if this is extension field\r\n\t\t\t\telse if(resultField.property.startsWith(\"@\"))\r\n\t\t\t\t{\r\n\t\t\t\t\tvalue = value.toString();\r\n\t\t\t\t\t\r\n\t\t\t\t\tif(resultType.equals(entityDetails.getEntityType()))\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tMap<String, Object> customFldMap = (Map)entityDetails.getExtendedTableDetails().getEntityField().get(result);\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\tif(customFldMap == null)\r\n\t\t\t\t\t\t{\r\n\t\t\t\t\t\t\tcustomFldMap = new HashMap<>();\r\n\t\t\t\t\t\t\tentityDetails.getExtendedTableDetails().getEntityField().set(result, customFldMap);\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t\t\r\n\t\t\t\t\t\tcustomFldMap.put(resultField.property.substring(1), value);\r\n\t\t\t\t\t\tcontinue;\r\n\t\t\t\t\t}\r\n\t\t\t\t\telse\r\n\t\t\t\t\t{\r\n\t\t\t\t\t\tString entityExtField = entityDetails.getExtendedTableDetails().getEntityField().getName();\r\n\t\t\t\t\t\t((IDynamicSearchResult)result).addField(new DynamicResultField(entityExtField + \".\" + resultField.property.substring(1), value));\r\n\t\t\t\t\t\tcontinue;\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t\t//if this is additional property field\r\n\t\t\t\telse if(resultField.property.startsWith(\"#\"))\r\n\t\t\t\t{\r\n\t\t\t\t\tvalue = conversionService.convertToJavaType(value, resultField.fieldDetails);\r\n\t\t\t\t\t((IDynamicSearchResult)result).addField(new DynamicResultField(resultField.property.substring(1), value));\r\n\t\t\t\t\tcontinue;\r\n\t\t\t\t}\r\n\t\t\t\t// if current field is a simple field (non relation field)\r\n\t\t\t\telse\r\n\t\t\t\t{\r\n\t\t\t\t\tvalue = conversionService.convertToJavaType(value, resultField.fieldDetails);\r\n\t\t\t\t\tvalue = ConvertUtils.convert(value, resultField.fieldType);\r\n\t\t\t\t}\r\n\t\t\t} catch(Exception ex)\r\n\t\t\t{\r\n\t\t\t\tthrow new InvalidStateException(ex, \"An error occurred while converting field {} value - {}\", resultField.fieldDetails.getName(), value);\r\n\t\t\t}\r\n\r\n\t\t\t// if value is null after conversion, ignore value\r\n\t\t\tif(value == null)\r\n\t\t\t{\r\n\t\t\t\tcontinue;\r\n\t\t\t}\r\n\r\n\t\t\tPropertyUtils.setProperty(result, resultField.property, value);\r\n\t\t}\r\n\r\n\t\t//if return type is target entity type, wrap result with proxy to take care of sub relations\r\n\t\tif(isEntityResultType)\r\n\t\t{\r\n\t\t\tICrudRepository<?> resultRepo = repositoryFactory.getRepositoryForEntity(resultType);\r\n\t\t\t\r\n\t\t\tresult = (T) ProxyEntityCreator.newProxyByEntity(resultRepo.getEntityDetails(), resultRepo, result, Collections.emptyMap());\r\n\t\t}\r\n\t\t\r\n\t\treturn result;\r\n\t}", "JAVATYPE convert(JAVATYPE oldValue, final METATYPE meta);", "public abstract SqlParameterSource getSqlParameterSource();", "@Override\r\n\t\t\t\t\tpublic void dragSetData(DragSourceEvent event) {\n\t\t\t\t\t\tLocalSelectionTransfer transfer=LocalSelectionTransfer.getTransfer();\r\n\t\t\t\t\t\tif (transfer.isSupportedType(event.dataType)) {\r\n\t\t\t\t\t\t\ttransfer.setSelection(tableViewer.getSelection());\r\n\t\t\t\t\t\t}\r\n\t\t\t\t\t}", "public Object transform(Object input) {\n try {\n iExecutor.execute(input);\n return input;\n\n } catch (ExecutorException ex) {\n throw new TransformerException(\"ExecutorTransformer: \" + ex.getMessage(), ex);\n }\n }", "public T convert(Number source)\r\n/* 26: */ {\r\n/* 27:56 */ return NumberUtils.convertNumberToTargetClass(source, this.targetType);\r\n/* 28: */ }", "Object adapt(final T src);", "Source updateDatasourceOAI(Source ds) throws RepoxException;", "public void updateTimestamp(@NotNull DataSource dataSource) {\n mySourceTimestamp = dataSource.getTimestamp();\n }", "public interface Transformer<T> extends Serializable{\n\n\t/**\n\t * Transform an input dataset into an output dataset (for example by adding an additional prediction attribute)\n\t */\n\tIStreamList<T> transform(IStreamList<T> dataset);\n\t\n}", "@Override\r\n public List<RelationalValueSource> relationalValueSources() {\n List<RelationalValueSource> valueSources = new ArrayList<RelationalValueSource>();\r\n valueSources.add(new ColumnSourceImpl(fieldMeta));\r\n return valueSources;\r\n }", "@Test\n public void testConversionFunction2() throws Exception {\n String sql = \"SELECT CONVERT(CONVERT(a, timestamp), string) FROM g\";\n Node fileNode = sequenceSql(sql, TSQL_QUERY);\n\n Node queryNode = verify(fileNode, Query.ID, Query.ID);\n\n Node selectNode = verify(queryNode, Query.SELECT_REF_NAME, Select.ID);\n Node function1Node = verifyExpressionSymbol(selectNode, Select.SYMBOLS_REF_NAME, Function.ID);\n verifyProperty(function1Node, Function.NAME_PROP_NAME, \"CONVERT\");\n\n Node function2Node = verify(function1Node, Function.ARGS_REF_NAME, 1, Function.ID);\n verifyProperty(function2Node, Function.NAME_PROP_NAME, \"CONVERT\");\n\n verifyElementSymbol(function2Node, Function.ARGS_REF_NAME, 1, \"a\");\n verifyConstant(function2Node, Function.ARGS_REF_NAME, 2, \"timestamp\");\n\n verifyConstant(function1Node, Function.ARGS_REF_NAME, 2, \"string\");\n\n Node fromNode = verify(queryNode, Query.FROM_REF_NAME, From.ID);\n verifyUnaryFromClauseGroup(fromNode, From.CLAUSES_REF_NAME, 1, \"g\");\n\n verifySql(sql, fileNode);\n }", "public Builder setTransformValue(godot.wire.Wire.Transform value) {\n if (transformValueBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n type_ = value;\n onChanged();\n } else {\n transformValueBuilder_.setMessage(value);\n }\n typeCase_ = 14;\n return this;\n }", "@Override\n @SuppressWarnings(\"unchecked\")\n public List<DataSink<?>> translateInto(Flow flow) {\n DAG<FlinkOperator<Operator<?, ?>>> dag = flowToDag(flow);\n\n BatchExecutorContext executorContext = new BatchExecutorContext(env, (DAG) dag,\n accumulatorFactory, settings);\n\n // translate each operator to proper Flink transformation\n dag.traverse().map(Node::get).forEach(op -> {\n Operator<?, ?> originalOp = op.getOriginalOperator();\n Translation<Operator<?, ?>> tx = translations.get(originalOp.getClass());\n if (tx == null) {\n throw new UnsupportedOperationException(\n \"Operator \" + op.getClass().getSimpleName() + \" not supported\");\n }\n // ~ verify the flowToDag translation\n Preconditions.checkState(\n tx.accept == null || Boolean.TRUE.equals(tx.accept.apply(originalOp)));\n\n DataSet<?> out = tx.translator.translate(op, executorContext);\n\n // save output of current operator to context\n executorContext.setOutput(op, out);\n });\n\n // process all sinks in the DAG (leaf nodes)\n final List<DataSink<?>> sinks = new ArrayList<>();\n dag.getLeafs()\n .stream()\n .map(Node::get)\n .filter(op -> op.output().getOutputSink() != null)\n .forEach(op -> {\n\n final DataSink<?> sink = op.output().getOutputSink();\n sinks.add(sink);\n DataSet<?> flinkOutput =\n Objects.requireNonNull(executorContext.getOutputStream(op));\n\n flinkOutput.output(new DataSinkWrapper<>((DataSink) sink));\n });\n\n return sinks;\n }", "Object getConvertedValue() throws ConversionException;", "public void process(String pathname) {\n\t\tFile file = new File( pathname );\n\t\tString filename = file.getName();\n\t\tString source = filename.substring( 5, filename.length()-19 );\n\t\tSQLDataSourceDescriptor dsd = sqlDataSourceHandler.getDataSourceDescriptor(source);\n\t\tif (dsd == null) {\n\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (datasource is invalid)\");\n\t\t\treturn;\n\t\t}\n\t\tSQLDataSource ds = null;\n\t\tVDXSource vds = null;\n\t\ttry {\n\t\t\tObject ods = dsd.getSQLDataSource();\n\t\t\tif (ods != null) {\n\t\t\t\tds = dsd.getSQLDataSource();\n\t\t\t}\n\t\t} catch (Exception e) {\n\t\t}\n\t\t\n\t\tint defaultRank = 0;\n\t\tint lineLen1, lineLen2;\n\t\tif ( ds != null ) {\n\t\t\t// This is an SQL DataSource\n\t\t\t\n\t\t\t// Build map of channels\n\t\t\tchannelMap = new HashMap<String, Integer>();\n\t\t\tfor ( Channel ch: ds.defaultGetChannelsList(false) )\n\t\t\t\tchannelMap.put( ch.getCode(), ch.getCID() );\n\t\t\tlogger.info( \"Channels mapped: \" + channelMap.size() );\n\t\t\t\n\t\t\t// Build map of columns\n\t\t\tcolumnMap = new HashMap<String, Integer>();\n\t\t\tfor ( Column col: ds.defaultGetColumns(true,ds.getMenuColumnsFlag()) )\n\t\t\t\tcolumnMap.put( col.name, col.idx );\n\t\t\tlogger.info( \"Columns mapped: \" + columnMap.size() );\n\t\t\t\n\t\t\t// Build map of ranks\n\t\t\trankMap = new HashMap<String, Integer>();\n\t\t\tfor ( String rk: ds.defaultGetRanks() ) {\n\t\t\t\tString rkBits[] = rk.split(\":\");\n\t\t\t\tint id = Integer.parseInt(rkBits[0]);\n\t\t\t\trankMap.put( rkBits[1], id );\n\t\t\t\tif ( rkBits[3].equals(\"1\") )\n\t\t\t\t\tdefaultRank = id;\n\t\t\t}\n\t\t\tlogger.info( \"Ranks mapped: \" + rankMap.size() );\n\t\t\t\n\t\t\t// Set limits on # args per input line\n\t\t\tlineLen1 = 7;\n\t\t\tlineLen2 = 9;\n\t\t\t\n\t\t\t// Build map of supp data types\n\t\t\tsdtypeMap = new HashMap<String, Integer>();\n\t\t\tfor ( SuppDatum sdt: ds.getSuppDataTypes() )\n\t\t\t\tsdtypeMap.put( sdt.typeName, sdt.tid );\n\t\t\tlogger.info( \"Suppdata types mapped: \" + sdtypeMap.size() );\n\t\t\t\n\t\t} else {\n\t\t\t// It isn't a SQL datasource; try it as a Winston datasource\n\t\t\tDataSourceDescriptor vdsd = dataSourceHandler.getDataSourceDescriptor(source);\n\t\t\ttry {\n\t\t\t\tvds = (VDXSource)vdsd.getDataSource();\n\t\t\t\tif ( vds == null ) {\n\t\t\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (datasource is invalid)\");\n\t\t\t\t\treturn;\n\t\t\t\t}\n\t\t\t} catch (Exception e2) {\n\t\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (datasource is invalid)\");\n\t\t\t\treturn;\n\t\t\t}\n\n\t\t\t// Build map of channels\n\t\t\tchannelMap = new HashMap<String, Integer>();\n\t\t\tfor ( gov.usgs.winston.Channel ch: vds.getChannels().getChannels() )\n\t\t\t\tchannelMap.put( ch.getCode(), ch.getSID() );\n\t\t\tlogger.info( \"Channels mapped: \" + channelMap.size() );\n\t\t\t\n\t\t\t// Set limits on # args per input line\n\t\t\tlineLen1 = lineLen2 = 7;\n\n\t\t\t// Build map of supp data types\n\t\t\tsdtypeMap = new HashMap<String, Integer>();\n\t\t\ttry {\n\t\t\t\tfor ( SuppDatum sdt: vds.getSuppDataTypes() )\n\t\t\t\t\tsdtypeMap.put( sdt.typeName, sdt.tid );\n\t\t\t\tlogger.info( \"Suppdata types mapped: \" + sdtypeMap.size() );\n\t\t\t} catch (Exception e3) {\n\t\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (problem reading supplemental data types)\");\n\t\t\t\treturn;\n\t\t\t}\n\t\t}\n\t\t\n\t\t// Access the input file\n\t\tResourceReader rr = ResourceReader.getResourceReader(pathname);\n\t\tif (rr == null) {\n\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (resource is invalid)\");\n\t\t\treturn;\n\t\t}\n\t\t// move to the first line in the file\n\t\tString line\t\t= rr.nextLine();\n\t\tint lineNumber\t= 0;\n\n\t\t// check that the file has data\n\t\tif (line == null) {\n\t\t\tlogger.log(Level.SEVERE, \"skipping: \" + pathname + \" (resource is empty)\");\n\t\t\treturn;\n\t\t}\n\t\t\n\t\tlogger.info(\"importing: \" + filename);\n\t\t\n\t\tSuppDatum sd = new SuppDatum();\n\t\tint success = 0;\n\t\t\n\t\t// we are now at the first row of data. time to import!\n\t\tString[] valueArray = new String[lineLen2];\n\t\twhile (line != null) {\n\t\t\tlineNumber++;\n\t\t\t// Build up array of values in this line\n\t\t\t// First, we split it by quotes\n\t\t\tString[] quoteParts = line.split(\"'\", -1);\n\t\t\tif ( quoteParts.length % 2 != 1 ) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", mismatched quotes\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\t// Next, walk through those parts, splitting those outside of matching quotes by comma\n\t\t\tint valueArrayLength = 0;\n\t\t\tboolean ok = true;\n\t\t\tfor ( int j=0; ok && j<quoteParts.length; j+=2 ) {\n\t\t\t\tString[] parts = quoteParts[j].split(\",\", -1);\n\t\t\t\tint k, k1 = 1, k2 = parts.length-1;\n\t\t\t\tboolean middle = true;\n\t\t\t\tif ( j==0 ) { // section before first quote\n\t\t\t\t\tmiddle = false;\n\t\t\t\t\tif ( parts.length > 1 && parts[0].trim().length() == 0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", leading comma\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tk1 --;\n\t\t\t\t} \n\t\t\t\tif ( j==quoteParts.length-1 ) { // section after last quote\n\t\t\t\t\tmiddle = false;\n\t\t\t\t\tif ( parts.length > 1 && parts[parts.length-1].trim().length() == 0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", trailing comma\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tk2++;\n\t\t\t\t}\n\t\t\t\tif ( middle ) {\n\t\t\t\t\tif ( parts.length == 1 ){\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", missing comma between quotes\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tif ( parts[0].trim().length()!=0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", missing comma after a quote\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tif ( parts[parts.length-1].trim().length()!=0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", missing comma before a quote\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tfor ( k=k1; ok && k<k2; k++ ) {\n\t\t\t\t\tif ( valueArrayLength == lineLen2 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", too many elements\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tvalueArray[valueArrayLength++] = parts[k];\n\t\t\t\t}\n\t\t\t\tif ( j+1 < quoteParts.length ) {\n\t\t\t\t\tif ( valueArrayLength == lineLen2 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", too many elements\");\n\t\t\t\t\t\tok = false;\n\t\t\t\t\t\tbreak;\n\t\t\t\t\t}\n\t\t\t\t\tvalueArray[valueArrayLength++] = quoteParts[j+1];\n\t\t\t\t}\n\t\t\t}\n\n\t\t\t// Line has been parsed; get next one\n\t\t\tline\t= rr.nextLine();\n\t\t\tif ( !ok )\n\t\t\t\tcontinue;\n\t\t\t\n\t\t\t// Validate & unmap arguments\n\t\t\tif ( valueArrayLength < lineLen1 ) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \", too few elements (\" + valueArrayLength + \")\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\ttry {\n\t\t\t\tsd.cid = channelMap.get( valueArray[3].trim() );\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\", unknown channel: '\" + valueArray[3] + \"'\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\ttry {\n\t\t\t\tsd.st = Double.parseDouble( valueArray[1].trim() );\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\", invalid start time: '\" + valueArray[1] + \"'\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\ttry {\n\t\t\t\tString et = valueArray[2].trim();\n\t\t\t\tif ( et.length() == 0 )\n\t\t\t\t\tsd.et = Double.MAX_VALUE;\n\t\t\t\telse\n\t\t\t\t\tsd.et = Double.parseDouble( et );\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\", invalid end time: '\" + valueArray[2] + \"'\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\ttry {\n\t\t\t\tsd.typeName = valueArray[4].trim();\n\t\t\t\tInteger tid = sdtypeMap.get( sd.typeName );\n\t\t\t\tif ( tid == null ) {\n\t\t\t\t\tsd.color = \"000000\";\n\t\t\t\t\tsd.dl = 1;\n\t\t\t\t\tsd.tid = -1;\n\t\t\t\t} else\n\t\t\t\t\tsd.tid = tid;\t\t\t\t\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\", couldn't create type: '\" + valueArray[4] + \"'\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\tif ( ds != null ) {\n\t\t\t\tif ( valueArrayLength > lineLen1 ) {\n\t\t\t\t\ttry {\n\t\t\t\t\t\tsd.colid = columnMap.get( valueArray[7].trim() );\n\t\t\t\t\t} catch (Exception e) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\", unknown column: '\" + valueArray[7] + \"'\");\n\t\t\t\t\t\tcontinue;\n\t\t\t\t\t}\n\t\t\t\t\tif ( valueArrayLength < lineLen2 ) {\n\t\t\t\t\t\tsd.rid = defaultRank;\n\t\t\t\t\t} else {\n\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\tsd.rid = rankMap.get( valueArray[8].trim() );\n\t\t\t\t\t\t} catch (Exception e) {\n\t\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\t\", unknown rank: '\" + valueArray[8] + \"'\");\n\t\t\t\t\t\t\tcontinue;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t} else {\n\t\t\t\t\tsd.colid = -1;\n\t\t\t\t\tsd.rid = -1;\n\t\t\t\t}\n\t\t\t} else {\n\t\t\t\tsd.colid = -1;\n\t\t\t\tsd.rid = -1;\n\t\t\t}\n\t\t\tsd.name = valueArray[5].trim();\n\t\t\tsd.value = valueArray[6].trim();\n\t\t\t\n\t\t\ttry {\n\t\t\t\tsd.sdid = Integer.parseInt( valueArray[0] );\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\", unknown id: '\" + valueArray[0] + \"'\");\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\t\n\t\t\t// Finally, insert/update the data\n\t\t\ttry {\n\t\t\t\tif ( ds != null ) {\n\t\t\t\t\tif ( sd.tid == -1 ) {\n\t\t\t\t\t\tsd.tid = ds.insertSuppDataType( sd );\n\t\t\t\t\t\tif ( sd.tid == 0 ) {\n\t\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\t\", problem inserting datatype\" );\n\t\t\t\t\t\t\tcontinue;\n\t\t\t\t\t\t}\n\t\t\t\t\t\tsdtypeMap.put( sd.typeName, sd.tid );\n\t\t\t\t\t\tlogger.info(\"Added supplemental datatype \" + sd.typeName );\n\t\t\t\t\t}\n\t\t\t\t\tint read_sdid = sd.sdid;\n\t\t\t\t\tif ( sd.sdid == 0 ) {\n\t\t\t\t\t\tsd.sdid = ds.insertSuppDatum( sd );\n\t\t\t\t\t} else\n\t\t\t\t\t\tsd.sdid = ds.updateSuppDatum( sd );\n\t\t\t\t\tif ( sd.sdid < 0 ) {\n\t\t\t\t\t\tsd.sdid = -sd.sdid;\n\t\t\t\t\t\tlogger.info(\"For import of line \" + lineNumber + \n\t\t\t\t\t\t\", supp data record already exists as SDID \" + sd.sdid +\n\t\t\t\t\t\t\"; will create xref record\");\n\t\t\t\t\t} else if ( sd.sdid==0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\", problem \" + (read_sdid==0 ? \"insert\" : \"updat\") + \"ing supp data\" );\n\t\t\t\t\t\tcontinue;\n\t\t\t\t\t} else if ( read_sdid == 0 )\n\t\t\t\t\t\tlogger.info(\"Added supp data record SDID \" + sd.sdid);\n\t\t\t\t\telse\n\t\t\t\t\t\tlogger.info(\"Updated supp data record SDID \" + sd.sdid);\n\t\t\t\t\tif ( !ds.insertSuppDatumXref( sd ) )\n\t\t\t\t\t\tcontinue;\n\t\t\t\t\telse\n\t\t\t\t\t\tlogger.info( \"Added xref for SDID \" + sd.sdid );\n\t\t\t\t} else {\n\t\t\t\t\tif ( sd.tid == -1 ) {\n\t\t\t\t\t\tsd.tid = vds.insertSuppDataType( sd );\n\t\t\t\t\t\tif ( sd.tid == 0 ) {\n\t\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\t\", problem inserting datatype\" );\n\t\t\t\t\t\t\tcontinue;\n\t\t\t\t\t\t}\n\t\t\t\t\t\tsdtypeMap.put( sd.typeName, sd.tid );\n\t\t\t\t\t\tlogger.info(\"Added supplemental datatype \" + sd.typeName );\n\t\t\t\t\t}\n\t\t\t\t\tint read_sdid = sd.sdid;\n\t\t\t\t\tif ( sd.sdid == 0 )\n\t\t\t\t\t\tsd.sdid = vds.insertSuppDatum( sd );\n\t\t\t\t\telse\n\t\t\t\t\t\tsd.sdid = vds.updateSuppDatum( sd );\n\t\t\t\t\tif ( sd.sdid < 0 ) {\n\t\t\t\t\t\tsd.sdid = -sd.sdid;\n\t\t\t\t\t\tlogger.info(\"For import of line \" + lineNumber + \n\t\t\t\t\t\t\", supp data record already exists as SDID \" + sd.sdid +\n\t\t\t\t\t\t\"; will create xref record\");\n\t\t\t\t\t} else if ( sd.sdid==0 ) {\n\t\t\t\t\t\tlogger.warning(\"Aborting import of line \" + lineNumber + \n\t\t\t\t\t\t\t\", problem \" + (read_sdid==0 ? \"insert\" : \"updat\") + \"ing supp data\" );\n\t\t\t\t\t\tcontinue;\n\t\t\t\t\t} else if ( read_sdid == 0 )\n\t\t\t\t\t\tlogger.info(\"Added supp data record SDID \" + sd.sdid);\n\t\t\t\t\telse\n\t\t\t\t\t\tlogger.info(\"Updated supp data record SDID \" + sd.sdid);\n\t\t\t\t\tif ( !vds.insertSuppDatumXref( sd ) )\n\t\t\t\t\t\tcontinue;\n\t\t\t\t\telse\n\t\t\t\t\t\tlogger.info( \"Added xref for SDID \" + sd.sdid );\n\t\t\t\t}\n\t\t\t} catch (Exception e) {\n\t\t\t\tlogger.warning(\"Failed import of line \" + lineNumber + \", db failure: \" + e);\n\t\t\t\tcontinue;\n\t\t\t}\n\t\t\tsuccess++;\n\t\t}\n\t\tlogger.info(\"\" + success + \" of \" + lineNumber + \" lines successfully processed\");\n\t}", "static public void setDataSource(DataSource source) {\n ds = source;\n }", "public Object convertToType(ELContext context, Object obj, Class<?> targetType) {\n/* 522 */ context.setPropertyResolved(false);\n/* */ \n/* 524 */ Object value = null;\n/* 525 */ for (int i = 0; i < this.size; i++) {\n/* 526 */ value = this.elResolvers[i].convertToType(context, obj, targetType);\n/* 527 */ if (context.isPropertyResolved()) {\n/* 528 */ return value;\n/* */ }\n/* */ } \n/* 531 */ return null;\n/* */ }", "@java.lang.Override\n public godot.wire.Wire.Transform2D getTransform2DValue() {\n if (transform2DValueBuilder_ == null) {\n if (typeCase_ == 9) {\n return (godot.wire.Wire.Transform2D) type_;\n }\n return godot.wire.Wire.Transform2D.getDefaultInstance();\n } else {\n if (typeCase_ == 9) {\n return transform2DValueBuilder_.getMessage();\n }\n return godot.wire.Wire.Transform2D.getDefaultInstance();\n }\n }", "public int castToIntegerValue() {\n throw new IteratorFlowException(\"Cannot call castToDouble on non numeric\");\n }", "@Test\r\n\tvoid testDataSourceConversionsWithExceptions() {\r\n\t\tDeconstructor underTest = sampleDataSource.deconstructor();\r\n\t\r\n\t\tIllegalStateException ex1 = assertThrows(IllegalStateException.class, ()->underTest.getByteArrayByName(DUMMY_DS_NAME).get());\r\n\t\tString msg1 = ex1.getMessage();\r\n\t\tassertNotNull(msg1);\r\n\t\tassertEquals(\"Error while converting DataSource to ByteArray\", msg1);\r\n\t\t\r\n\t\tIllegalStateException ex2 = assertThrows(IllegalStateException.class, ()->underTest.getStringByName(DUMMY_DS_NAME).get());\r\n\t\tString msg2 = ex2.getMessage();\r\n\t\tassertNotNull(msg2);\r\n\t\tassertEquals(\"Error while converting DataSource to String\", msg2);\r\n\t}", "public interface TimeStreamMapToScalar {\n double map(Object x);\n}", "public T caseMeasurementValueSource(MeasurementValueSource object) {\n\t\treturn null;\n\t}", "public TemporaryDataSource(DataSource dataSource){\n\t\tthis.ds = dataSource;\n\t}", "@Deprecated\n/* */ public double convert(double amount, LengthUnit otherUnit) {\n/* 45 */ Dx Dx2 = new Dx(amount, otherUnit);\n/* 46 */ return Dx2.convertTo(this).getValue();\n/* */ }", "TickSource getSource();", "public interface Converter {\n\n public double convert(String converterName, double value);\n}", "public interface SQLTransform {\n\n\t/**\n\t * Generate code to put into cursor, the bean property value.\n\t *\n\t * @param tableEntity entity with table to target\n\t * @param methodBuilder the method builder\n\t * @param beanClass the bean class\n\t * @param beanName the bean name\n\t * @param property the property\n\t * @param cursorName the cursor name\n\t * @param indexName the index name\n\t */\n\tvoid generateReadPropertyFromCursor(SQLiteEntity tableEntity, Builder methodBuilder, TypeName beanClass, String beanName, ModelProperty property, String cursorName, String indexName);\n\n\t/**\n\t * Used when you need to use a cursor column as select's result value. \n\t *\n\t * @param methodBuilder the method builder\n\t * @param daoDefinition the dao definition\n\t * @param paramTypeName the param type name\n\t * @param cursorName the cursor name\n\t * @param indexName the index name\n\t */\n\tvoid generateReadValueFromCursor(Builder methodBuilder, SQLiteDaoDefinition daoDefinition, TypeName paramTypeName, String cursorName, String indexName);\n\n\t/**\n\t * Generate default value, null or 0 or ''.\n\t *\n\t * @param methodBuilder the method builder\n\t */\n\tvoid generateDefaultValue(Builder methodBuilder);\n\n\t/**\n\t * Write a bean property to a content writer.\n\t *\n\t * @param methodBuilder the method builder\n\t * @param beanName the bean name\n\t * @param beanClass the bean class\n\t * @param property property to write\n\t */\n\tvoid generateWriteProperty2ContentValues(Builder methodBuilder, String beanName, TypeName beanClass, ModelProperty property);\n\t\n\t/**\n\t * Write a bean property into a where condition.\n\t *\n\t * @param methodBuilder the method builder\n\t * @param beanName the bean name\n\t * @param beanClass the bean class\n\t * @param property the property\n\t */\n\tvoid generateWriteProperty2WhereCondition(Builder methodBuilder, String beanName, TypeName beanClass, ModelProperty property);\n\n\t/**\n\t * <p>\n\t * Generate code to write parameter to where condition\n\t * </p>.\n\t *\n\t * @param methodBuilder the method builder\n\t * @param method the method\n\t * @param paramName the param name\n\t * @param paramTypeName the param type name\n\t */\n\tvoid generateWriteParam2WhereCondition(Builder methodBuilder, SQLiteModelMethod method, String paramName, TypeName paramTypeName);\n\t\n\t/**\n\t * <p>Generate code to write parameter to where statement</p>.\n\t *\n\t * @param methodBuilder the method builder\n\t * @param method the method\n\t * @param paramName the param name\n\t * @param paramType the param type\n\t * @param property the property\n\t */\n\tvoid generateWriteParam2ContentValues(Builder methodBuilder, SQLiteModelMethod method, String paramName, TypeName paramType, ModelProperty property);\n\n\t/**\n\t * Generate code to set property to null value or default value.\n\t *\n\t * @param methodBuilder the method builder\n\t * @param beanClass the bean class\n\t * @param beanName the bean name\n\t * @param property the property\n\t * @param cursorName the cursor name\n\t * @param indexName the index name\n\t */\n\tvoid generateResetProperty(Builder methodBuilder, TypeName beanClass, String beanName, ModelProperty property, String cursorName, String indexName);\n\n\t/**\n\t * Associated column type.\n\t *\n\t * @return column type as string\n\t */\n\tString getColumnTypeAsString();\n\n\t/**\n\t * Gets the column type.\n\t *\n\t * @return column type\n\t */\n\tColumnAffinityType getColumnType();\n\t\n\t/**\n\t * if true, transform can be used as convertion type in a type adapter.\n\t *\n\t * @return true, if is type adapter aware\n\t */\n\tboolean isTypeAdapterAware();\n\n}", "public synchronized ContentValues prepareDataSource(DataSource dataSource) {\n byte[] dataSourceArray = toBytes(dataSource);\n long curTime = DateTime.getDateTime();\n ContentValues cValues = new ContentValues();\n\n if (dataSource.getId() != null)\n cValues.put(C_DATASOURCE_ID, dataSource.getId());\n if (dataSource.getType() != null)\n cValues.put(C_DATASOURCE_TYPE, dataSource.getType());\n if (dataSource.getPlatform() != null && dataSource.getPlatform().getId() != null)\n cValues.put(C_PLATFORM_ID, dataSource.getPlatform().getId());\n if (dataSource.getPlatform() != null && dataSource.getPlatform().getType() != null)\n cValues.put(C_PLATFROM_TYPE, dataSource.getPlatform().getType());\n if (dataSource.getPlatformApp() != null && dataSource.getPlatformApp().getId() != null)\n cValues.put(C_PLATFORMAPP_ID, dataSource.getPlatformApp().getId());\n if (dataSource.getPlatformApp() != null && dataSource.getPlatformApp().getType() != null)\n cValues.put(C_PLATFROMAPP_TYPE, dataSource.getPlatformApp().getType());\n if (dataSource.getApplication() != null && dataSource.getApplication().getId() != null)\n cValues.put(C_APPLICATION_ID, dataSource.getApplication().getId());\n if (dataSource.getApplication() != null && dataSource.getApplication().getType() != null)\n cValues.put(C_APPLICATION_TYPE, dataSource.getApplication().getType());\n cValues.put(C_CREATEDATETIME, curTime);\n cValues.put(C_DATASOURCE, dataSourceArray);\n return cValues;\n }", "public void fromTransformations(Transformations transformations);", "protected boolean transformIncomingData() {\r\n\t\tboolean rB=false;\r\n\t\tArrayList<String> targetStruc ;\r\n\t\t\r\n\t\t\r\n\t\ttry {\r\n\t\t\t\r\n\t\t\tif (transformationModelImported == false){\r\n\t\t\t\testablishTransformationModel();\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t// soappTransform.requiredVariables\r\n\t\t\tif (transformationsExecuted == false){\r\n\t\t\t\texecuteTransformationModel();\r\n\t\t\t}\r\n\t\t\trB = transformationModelImported && transformationsExecuted ;\r\n\t\t\t\r\n\t\t} catch (Exception e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\treturn rB;\r\n\t}", "public interface ValueConverter\n{\n\n\tObject convertToX( String sourceValue, Class targetType, String propertyName );\n\n\tString convertToString( Object sourceValue, String propertyName );\n\n}", "public static Object convert(Object srcValue, Class<?> targetCls)\n\t\tthrows ApplicationException\n\t{\n\t\tObject result=srcValue;\n\n\t\tClass srcClass=((null==srcValue) ? null : srcValue.getClass());\n\t\tClass dtClass=DateTime.class;\n\n\t\tif (((null==srcValue) || Converter.isPrimitiveType(srcClass)) && Converter.isPrimitiveType(targetCls))\n\t\t{\n\t\t\tresult=(null==srcValue) ? null : targetCls.cast(srcValue);\n\t\t}\n\t\telse if (ClassX.isKindOf(targetCls, URI.class))\n\t\t{\n\t\t\tif (null!=srcValue)\n\t\t\t{\n\t\t\t\tresult=URI.create(srcValue.toString());\n\t\t\t}\n\t\t}\n\t\telse if (ClassX.isKindOf(targetCls, dtClass))\n\t\t{\n\t\t\tif (null==srcValue)\n\t\t\t{\n\t\t\t\tresult=null;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tString date=srcValue.toString().toLowerCase();\n\t\t\t\tdate=date.replace(\"/date(\", \"\");\n\t\t\t\tdate=date.replace(\")/\", \"\");\n\n\t\t\t\t// Remove the timezone offset value\n\t\t\t\tif (date.contains(\"+\"))\n\t\t\t\t{\n\t\t\t\t\tString[] parts=Converter.PATTERN_UTC_OFFSET.split(date);\n\t\t\t\t\tdate=parts[0];\n\t\t\t\t\t// The second value is the time zone offset but we will always use UTC.\n\t\t\t\t}\n\n\t\t\t\t// double values can not be parsed to DateTime\n\t\t\t\tif (date.contains(\"\"))\n\t\t\t\t{\n\t\t\t\t\tString[] parts=Converter.PATTERN_BACKSLASH.split(date);\n\t\t\t\t\tdate=parts[0];\n\t\t\t\t}\n\t\t\t\tLong dtLong=Long.valueOf(date);\n\t\t\t\tresult=new DateTime(dtLong, DateTimeZone.UTC);\n\t\t\t}\n\t\t}\n\t\telse if (ClassX.implementsInterface(targetCls, Convertible.class))\n\t\t{\n\t\t\tConvertible convertibleTarget;\n\t\t\ttry\n\t\t\t{\n\t\t\t\tconvertibleTarget=(Convertible) targetCls.getConstructor().newInstance();\n\t\t\t}\n\t\t\tcatch (Exception e)\n\t\t\t{\n\t\t\t\tthrow new ApplicationException(e);\n\t\t\t}\n\t\t\tif ((null==srcClass) || convertibleTarget.canConvertFrom(srcClass))\n\t\t\t{\n\t\t\t\tconvertibleTarget.convertFrom(srcValue);\n\t\t\t\tresult=convertibleTarget;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tthrow new ClassCastException(\n\t\t\t\t\tString.format(\n\t\t\t\t\t\t\"'%s' does not support converting from '%s'.\", targetCls.getName(), srcClass.getName()\n\t\t\t\t\t)\n\t\t\t\t);\n\t\t\t}\n\t\t}\n\t\telse if (ClassX.implementsInterface(srcClass, Convertible.class))\n\t\t{\n\t\t\tConvertible convertibleSrc=(Convertible) srcValue;\n\t\t\tif ((null!=srcClass) && convertibleSrc.canConvertTo(srcClass))\n\t\t\t{\n\t\t\t\tresult=convertibleSrc.convertTo(targetCls);\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tthrow new ClassCastException(\n\t\t\t\t\tString.format(\n\t\t\t\t\t\t\"'%s' does not support converting to '%s'.\", ((null==srcClass) ? \"unknown source Class\" : srcClass.getName()),\n\t\t\t\t\t\t(targetCls!=null) ? targetCls.getName() : \"unknown target class\"\n\t\t\t\t\t)\n\t\t\t\t);\n\t\t\t}\n\t\t}\n\n\t\treturn result;\n\t}", "public void setSource(float xx, float yy);", "default Object convert(GenericRowData row) {\n return convert(row, -1);\n }", "@Override\n\t@Transactional(propagation = Propagation.REQUIRED)\n\tpublic void compareDataSource(QualityQuery data) throws Exception {\n\t\tList<DataSourceResult> resultList = metaDataFetchService.listFromColumnResult(data);\n\t\tmetaDataModifyService.mergeDqDataSourceResult(data.getBatchId(), resultList);\n\t}", "public interface DboCsvTransformer<DBO extends DatabaseObject<?>> extends DboFileTransformer<DBO> {\n\n String COMMA_IN_QUOTES_REGEX = \",(?=(?:[^\\\\\\\"]*\\\\\\\"[^\\\\\\\"]*\\\\\\\")*[^\\\\\\\"]*$)\";\n\n /**\n * This method consumes a single line of CSV to produce a DatabaseObject.\n *\n * @param csv the single line of CSV representing a single DatabaseObject\n * @return the DatabaseObject represented\n * @throws TransformerException if the object cannot be produced\n */\n @Override\n DBO consume(String csv) throws TransformerException;\n\n /**\n * This method consumes a DatabaseObject to produce a String in CSV format.\n *\n * @param object the DatabaseObject\n * @return a String in CSV format\n * @throws TransformerException if the object cannot be consumed\n */\n @Override\n String produce(DBO object) throws TransformerException;\n\n}", "public interface DataItemSource {\n\tpublic String getDataItemSourceName();\n\n\t/**\n\t * \n\t * @return A new object of the same class as the caller. All fields are reinitialized\n\t * to default state except for the disabled field, which will have the same value as the caller\n\t */\n\tpublic DataItemSource createInstanceOfSameType();\n\n\tpublic boolean isDisabled();\n\n\tpublic void setDisabled(boolean b);\n\n\tpublic ImageIcon getProfileIcon();\n\n}", "@Override\n\t\t\tpublic void dragSetData (DragSourceEvent event) {\n\t\t\t\tif (TextTransfer.getInstance().isSupportedType (event.dataType)) {\n\t\t\t\t\tevent.data = dragLabel.getText ();\n\t\t\t\t}\n\t\t\t}", "public void createDataTypeProperty(String sourceInstance, String propertyName, Object value)\r\n\t{\r\n\t\tOntResource si = this.obtainOntResource(sourceInstance);\r\n\t\tProperty prop = this.obtainOntProperty(propertyName);\r\n\t\tsi.addProperty(prop, ONT_MODEL.createTypedLiteral(value)); \t\r\n\t}", "public void setDatasource(DataSource source) {\n datasource = source;\n }", "public interface TransformFunc<FROM, TO>\r\n{\r\n TO transform(FROM source);\r\n}", "private static void applyTransformations(DataFrame dataFrame) {\n // apply all transformations of every column\n for (GenericColumn column : dataFrame.getColumns()) {\n try {\n for (Transformer transformer : column.getTransformers()) {\n dataFrame.transformColumn(column, transformer);\n }\n } catch (Exception e) {\n throw AnchorTabularBuilderException.transformationException(column, e);\n }\n }\n }", "public DataSource generateShardingSphereDataSourceFromProxy() {\n Awaitility.await().atMost(5L, TimeUnit.SECONDS).pollInterval(1L, TimeUnit.SECONDS).until(() -> null != getYamlRootConfig().getRules());\n YamlRootConfiguration rootConfig = getYamlRootConfig();\n ShardingSpherePreconditions.checkNotNull(rootConfig.getDataSources(), () -> new IllegalStateException(\"dataSources is null\"));\n ShardingSpherePreconditions.checkNotNull(rootConfig.getRules(), () -> new IllegalStateException(\"rules is null\"));\n if (PipelineEnvTypeEnum.DOCKER == PipelineE2EEnvironment.getInstance().getItEnvType()) {\n DockerStorageContainer storageContainer = ((DockerContainerComposer) containerComposer).getStorageContainers().get(0);\n String sourceUrl = String.join(\":\", storageContainer.getNetworkAliases().get(0), Integer.toString(storageContainer.getExposedPort()));\n String targetUrl = String.join(\":\", storageContainer.getHost(), Integer.toString(storageContainer.getMappedPort()));\n for (Map<String, Object> each : rootConfig.getDataSources().values()) {\n each.put(\"url\", each.get(\"url\").toString().replaceFirst(sourceUrl, targetUrl));\n }\n }\n for (Map<String, Object> each : rootConfig.getDataSources().values()) {\n each.put(\"dataSourceClassName\", \"com.zaxxer.hikari.HikariDataSource\");\n }\n YamlSingleRuleConfiguration singleRuleConfig = new YamlSingleRuleConfiguration();\n singleRuleConfig.setTables(Collections.singletonList(\"*.*\"));\n rootConfig.getRules().add(singleRuleConfig);\n return PipelineDataSourceFactory.newInstance(new ShardingSpherePipelineDataSourceConfiguration(rootConfig));\n }", "@Override\r\n protected double initValue()\r\n {\n try\r\n {\r\n interpFlow = InterpolaterFactory.create(tableName.v);\r\n return computeValue();\r\n }\r\n catch (Throwable t)\r\n {\r\n Logger.logError(t.getMessage());\r\n return 0;\r\n }\r\n }" ]
[ "0.5852458", "0.52779526", "0.51329017", "0.51262206", "0.5117311", "0.5114573", "0.50593334", "0.5048154", "0.5009793", "0.499437", "0.4979994", "0.49280253", "0.490887", "0.4871801", "0.48491186", "0.48203564", "0.4819449", "0.48134375", "0.47985485", "0.4795591", "0.47775078", "0.47761288", "0.47707927", "0.47642896", "0.47607598", "0.47581688", "0.47571084", "0.47312793", "0.47219542", "0.47208124", "0.47198117", "0.4714708", "0.47030008", "0.46906272", "0.46878445", "0.46873304", "0.46821022", "0.467988", "0.46564385", "0.46533754", "0.46518093", "0.46497348", "0.46294293", "0.46281832", "0.46186626", "0.4612851", "0.46111667", "0.46102375", "0.4609658", "0.460092", "0.4596011", "0.45959958", "0.4594268", "0.45820063", "0.45764136", "0.4576103", "0.4572319", "0.45719016", "0.45675957", "0.45674953", "0.45612198", "0.45510757", "0.45382434", "0.4535423", "0.453505", "0.453195", "0.4503626", "0.44866645", "0.4484507", "0.44821098", "0.4481923", "0.44805354", "0.44799238", "0.4477902", "0.44725916", "0.4472408", "0.44693282", "0.44681168", "0.44677597", "0.44656843", "0.44628704", "0.4460723", "0.4458889", "0.44564727", "0.44558915", "0.44416782", "0.44415146", "0.44404283", "0.44341302", "0.4432862", "0.44296843", "0.44294268", "0.44264275", "0.44259164", "0.44247404", "0.44183964", "0.4417348", "0.44135922", "0.44126", "0.44121736" ]
0.55125177
1
TrimmedDataSource Make a list that is a window on another list. Sometimes you might want some calculation of the next N numbers of a list (for example sum the next 100 numbers of a list). You can define a trimmed view of a list and pass the trimmed list to algorithms that do further calculations.
@SuppressWarnings("unused") void example15() { // make a list of 10,000 numbers IndexedDataSource<Float32Member> original = nom.bdezonia.zorbage.storage.Storage.allocate(G.FLT.construct(), 10000); // make a list that is a subset of the previous list (numbers from locations 1,000 - 2,999) IndexedDataSource<Float32Member> trimmed = new TrimmedDataSource<>(original, 1000, 2000); // the trimmed list has length 2,000 and is indexed from 0 to 1,999 returning data from // locations 1,000 - 2,999 in the original list. }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@SuppressWarnings(\"unused\")\n\tvoid example17() {\n\t\t\n\t\t// make a list of 10,000 numbers\n\t\t\n\t\tIndexedDataSource<Float32Member> original =\n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.FLT.construct(), 10000);\n\n\t\t// make a list that is a subset of the previous list (numbers from locations 1,000 - 2,999)\n\t\t\n\t\tIndexedDataSource<Float32Member> trimmed = new TrimmedDataSource<>(original, 1000, 2000);\n\t\t\n\t\t// then create a new memory copy of those 2000 numbers\n\t\t\n\t\tIndexedDataSource<Float32Member> theCopy = DeepCopy.compute(G.FLT, trimmed);\n\t}", "@Nonnull\r\n\tpublic static <T> Observable<Observable<T>> window(\r\n\t\t\t@Nonnull Observable<? extends T> source, int size, int skip) {\r\n\t\treturn new Windowing.WithSizeSkip<T>(source, size, skip);\r\n\t}", "private static void cutSticks(ArrayList<Integer> numbers, int min) {\n\t\tint length = numbers.size();\n\t\t\n\t\twhile(min < Integer.MAX_VALUE){\n\t\t\tSystem.out.println(numbers.size());\n\t\t\tint newMin = Integer.MAX_VALUE;\n\t\t\tfor(int i = 0; i < numbers.size(); i++){\n\t\t\t\tint newno = numbers.get(i) - min;\n\t\t\t\tif(newno > 0){\n\t\t\t\t\tnumbers.set(i, numbers.get(i) - min);\n\t\t\t\t\tif(newno < newMin){\n\t\t\t\t\t\tnewMin = newno;\n\t\t\t\t\t}\n\t\t\t\t}else{\n\t\t\t\t\tnumbers.remove(i);\n\t\t\t\t\ti--;\n\t\t\t\t}\t\t\t\t\n\t\t\t}\n\t\t\tmin = newMin;\n\t\t}\n\t\t\n\t}", "public void devideDataWindow(int from, int to) {\n int i = 0, j = 0, interval = to - from;\n testingSet = new Double[interval][2];\n trainingSet = new Double[data.length - interval][2];\n while (i + j < data.length) {\n if (i + j >= from && i + j < to) {\n testingSet[i][0] = data[i + j][0];\n testingSet[i][1] = data[i + j][1];\n i++;\n } else {\n trainingSet[j][0] = data[i + j][0];\n trainingSet[j][1] = data[i + j][1];\n j++;\n }\n }\n }", "public MedianDatasource() {\n super(generateStacks(calculateStackCount(5, 100, 200), 15, 30,\n new double[]{50, 40, 35, 30, 20, 10, 7, 5, 2}, 3));\n }", "private void createTrimBars(MPerspective perspective) {\n\t\tList<MUIElement> minimizedElements = modelService.findElements(perspective, null, MUIElement.class,\r\n\t\t\t\tArrays.asList(IPresentationEngine.MINIMIZED));\r\n\t\tfor (MUIElement element : minimizedElements) {\r\n\t\t\tcreateTrim(element, perspective);\r\n\t\t}\r\n\t}", "private List<SpringDelta> buildResizableList(int axis,\n boolean useMin) {\n // First pass, figure out what is resizable\n int size = springs.size();\n List<SpringDelta> sorted = new ArrayList<SpringDelta>(size);\n for (int counter = 0; counter < size; counter++) {\n Spring spring = getSpring(counter);\n int sDelta;\n if (useMin) {\n sDelta = spring.getPreferredSize(axis) -\n spring.getMinimumSize(axis);\n } else {\n sDelta = spring.getMaximumSize(axis) -\n spring.getPreferredSize(axis);\n }\n if (sDelta > 0) {\n sorted.add(new SpringDelta(counter, sDelta));\n }\n }\n Collections.sort(sorted);\n return sorted;\n }", "private void removeList()\r\n {\n if (tableCheckBinding != null)\r\n {\r\n tableCheckBinding.dispose();\r\n tableCheckBinding = null;\r\n }\r\n\r\n // m_TableViewer.setInput(null);\r\n WritableList newList = new WritableList(SWTObservables.getRealm(Display.getDefault()));\r\n for (int i = 0; i < 10; ++i)\r\n {\r\n newList.add(this.generateNewDataModelItem());\r\n }\r\n m_TableViewer.setInput(newList);\r\n }", "private void sampleOfTheGeneratedWindowedAggregate() {\n Iterator<Integer[]> iterator = null;\n\n // builder3\n Integer[] rows = iterator.next();\n\n int prevStart = -1;\n int prevEnd = -1;\n\n for ( int i = 0; i < rows.length; i++ ) {\n // builder4\n Integer row = rows[i];\n\n int start = 0;\n int end = 100;\n if ( start != prevStart || end != prevEnd ) {\n // builder5\n int actualStart = 0;\n if ( start != prevStart || end < prevEnd ) {\n // builder6\n // recompute\n actualStart = start;\n // implementReset\n } else { // must be start == prevStart && end > prevEnd\n actualStart = prevEnd + 1;\n }\n prevStart = start;\n prevEnd = end;\n\n if ( start != -1 ) {\n for ( int j = actualStart; j <= end; j++ ) {\n // builder7\n // implementAdd\n }\n }\n // implementResult\n // list.add(new Xxx(row.deptno, row.empid, sum, count));\n }\n }\n // multiMap.clear(); // allows gc\n // source = Linq4j.asEnumerable(list);\n }", "private static void trim( List<?> list, int n ) {\n \twhile (list.size() > n) {\n \t\tlist.remove(list.size() - 1);\n \t}\n }", "private List<Coordinate> trim(List<Coordinate> list) {\n\n List<Coordinate> temp = new ArrayList<>();\n if (list.size() == 0) {\n return temp;\n }\n temp.add(list.get(0));\n for (int i = 1; i < list.size(); i++) {\n if (list.get(i - 1).equals(list.get(i))) {\n continue;\n }\n temp.add(list.get(i));\n }\n return temp;\n }", "private List<List<Integer>> allPartitions(Set<Integer> layoutSizes, int target, int sizeLimit) {\n List<List<Integer>> result = new ArrayList<>();\n layoutSizes = layoutSizes.stream().filter(x -> x > 0).collect(toSet());\n if (sizeLimit < 1) {\n sizeLimit = target;\n }\n Integer[] arr = new Integer[sizeLimit];\n generatePartialList(result, arr, 0, 0, layoutSizes, target, sizeLimit);\n return result;\n }", "void trim(int startingBlockId, int count) throws IOException;", "private void resize() {\n int listSize = numItemInList();\n //debug\n //System.out.println(\"resize: \" + nextindex + \"/\" + list.length + \" items:\" + listSize);\n if (listSize <= list.length / 2) {\n for (int i = 0; i < listSize; i++) {\n list[i] = list[startIndex + i];\n }\n } else {\n Object[] newList = new Object[this.list.length * 2];\n\n// System.arraycopy(this.list, startIndex, newList, 0, this.list.length-startIndex);\n for (int i = 0; i < listSize; i++) {\n newList[i] = list[i + startIndex];\n }\n this.list = newList;\n //debug\n //System.out.println(\"After resize:\" + nextindex + \" / \" + list.length + \" items:\" + numItemInList());\n }\n nextindex = nextindex - startIndex;\n startIndex = 0;\n }", "void example4() {\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> list1 = \n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.UINT1.construct(), 100);\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> list2 = \n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.UINT1.construct(), 1000);\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> joinedList =\n\t\t\t\tnew ConcatenatedDataSource<>(list1, list2);\n\t\t\n\t\tFill.compute(G.UINT1, G.UINT1.random(), joinedList);\n\t}", "private static List<SequenceDatabase> createSegmentDatabases(SequencesHelper sequencesHelper, int win_size){\n\t\tList<Date> dates = sequencesHelper.getDates();\n\t\tList<Sequence> sequences = sequencesHelper.getSequences();\n\t\tList<SequenceDatabase> segmentdbs = new LinkedList<SequenceDatabase>();\n\t\t\n\t\tint volumn_max = win_size; // Maximum number of intervals with trajectories\n\t\tint volumn_min = win_size / 2;\t// minimum number of intervals with trajectories\n\t\tint width_max = time_span_max;\n\t\tint width_min = time_span_min;\n\t\t\n\t\tassert(dates.size() == sequences.size());\n\t\t\n\t\tDate date_max = dates.get(dates.size()-1);\n\t\tint date_start = 0;\n\t\tint date_end = 0;\n\t\t\n\t\twhile (date_max.getTime()/1000 - dates.get(date_start).getTime()/1000 >= width_min * 24 * 3600){\n\t\t\t// start a new segment database\n\t\t\tSequenceDatabase newdb = new SequenceDatabase();\n\t\t\t\n\t\t\tfor (int i=date_start; i < dates.size(); i++){\n\t\t\t\tif ( newdb.size() < volumn_max && \n\t\t\t\t\t(dates.get(i).getTime()/1000 - dates.get(date_start).getTime()/1000) < width_max * 24 * 3600){\n\t\t\t\t\tnewdb.addSequence(sequencesHelper.getSequence(i), dates.get(i));\n\t\t\t\t\tdate_end = i;\n\t\t\t\t}else{\n\t\t\t\t\tbreak; // for\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t\tif ( newdb.size() >= volumn_min && newdb.getTimeSpanDays() >= width_min){\n\t\t\t\t// only add the database meeting the constraints.\n\t\t\t\tsegmentdbs.add(newdb);\n\t\t\t}\n\t\t\t\n\t\t\t// update date start index\n\t\t\tif ( newdb.size() > 1){\n\t\t\t\tList<Date> newdb_dates = newdb.getDates();\n\t\t\t\tDate start = newdb_dates.get(0);\n\t\t\t\tDate end = newdb_dates.get(newdb.size()-1);\n\t\t\t\t// the sliding distance depends on the median time of the sliding window.\n\t\t\t\tdouble time_middle = 0.5*(end.getTime()/1000 + start.getTime()/1000 );\n\t\t\t\tfor (int j = date_start; j <= date_end; j++){\n\t\t\t\t\tif (dates.get(j).getTime()/1000 >= time_middle){\n\t\t\t\t\t\tdate_start = j;\n\t\t\t\t\t\tdate_end = j;\n\t\t\t\t\t\tbreak; // inner for\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t} else\n\t\t\t\tdate_start = date_start+1;\n\t\t}\n\n\t\treturn segmentdbs;\n\t}", "static public Object trimArray(Object[] list,int newSize) {\n Class type = list.getClass().getComponentType();\n Object temp = Array.newInstance(type, newSize);\n System.arraycopy(list, 0, temp, 0,\tnewSize); \n return temp;\n\t}", "@Override\n public ArrayList<int[]> Split()\n {\n double hypervolume_best = -Double.MAX_VALUE;\n int hypervolume_best_i = 0;\n int hypervolume_best_j = 0;\n double hypervolume = 0d;\n\n for( int i = 0; i < Capacity_max + 1; i++)\n {\n for( int j = i + 1; j < Capacity_max + 1; j++)\n {\n hypervolume = 0d;\n double[] point1 = PointMatrix[ Items.get(i)[0] ][ Items.get(i)[1] ];\n double[] point2 = PointMatrix[ Items.get(j)[0] ][ Items.get(j)[1] ];\n\n for(int a = 0; a < Dimensions; a++)\n {\n if( point1[a] > point2[a] )\n hypervolume += Math.log10(point1[a] - point2[a]);\n if( point1[a] < point2[a] )\n hypervolume += Math.log10(point2[a] - point1[a]);\n }\n\n if( hypervolume_best < hypervolume)\n {\n hypervolume_best_i = i;\n hypervolume_best_j = j;\n hypervolume_best = hypervolume;\n }\n }\n }\n\n // Ready the split\n ArrayList<int[]> items_split = new ArrayList<>();\n items_split.addAll(Items);\n\n int point1_x = items_split.get(hypervolume_best_i)[0];\n int point1_y = items_split.get(hypervolume_best_i)[1];\n int point2_x = items_split.get(hypervolume_best_j)[0];\n int point2_y = items_split.get(hypervolume_best_j)[1];\n double[] point1 = PointMatrix[ point1_x ][ point1_y ];\n double[] point2 = PointMatrix[ point2_x ][ point2_y ];\n\n if(hypervolume_best_i > hypervolume_best_j)\n {\n items_split.remove(hypervolume_best_i);\n items_split.remove(hypervolume_best_j);\n }\n else\n {\n items_split.remove(hypervolume_best_j);\n items_split.remove(hypervolume_best_i);\n }\n\n // Create new box with point1\n BoundingBoxLeaf box1 = new BoundingBoxLeaf( PointMatrix, ParentBox, Tree, Depth, point1_x, point1_y );\n\n box1.SetBoxToFit(point1);\n box1.SetCoordsToFit( point1_x, point1_y);\n \n // Reset this box, and add point2\n BoundingBoxLeaf box2 = this;\n \n box2.SetBoxToFit(point2);\n box2.SetCoordsToFit( point2_x, point2_y);\n\n box2.Items.clear();\n box2.Items.add( new int[]{ point2_x, point2_y } );\n\n // Notify parent of split\n ParentBox.InsertBox_internal(box1);\n \n // Add items to the new boxes, up to min capacity\n int[] item_best;\n \n // box1\n while( box1.IsBelowMinCapacity() && !items_split.isEmpty() )\n {\n hypervolume_best = Double.MAX_VALUE;\n item_best = null;\n int index_best = -1;\n \n for(int i = 0; i < items_split.size(); i++ )\n {\n int[] item = items_split.get(i);\n double[] point = PointMatrix[ item[0] ][ item[1] ];\n \n hypervolume = box1.GetHyperVolume( point );\n \n if(hypervolume_best > hypervolume)\n {\n hypervolume_best = hypervolume;\n item_best = item; \n index_best = i;\n }\n \n }\n \n if(item_best != null)\n {\n box1.Items.add( new int[]{ item_best[0], item_best[1] } );\n box1.ExpandBoxToFit( PointMatrix[ item_best[0] ][ item_best[1] ] );\n box1.ExpandCoordsToFit( item_best[0], item_best[1]);\n \n items_split.remove(index_best);\n }\n }\n \n // box2\n while( box2.IsBelowMinCapacity() && !items_split.isEmpty() )\n {\n hypervolume_best = Double.MAX_VALUE;\n item_best = null;\n int index_best = -1;\n \n for(int i = 0; i < items_split.size(); i++ )\n {\n int[] item = items_split.get(i);\n double[] point = PointMatrix[ item[0] ][ item[1] ];\n hypervolume = box1.GetHyperVolume( point );\n \n if(hypervolume_best > hypervolume)\n {\n hypervolume_best = hypervolume;\n item_best = item; \n index_best = i;\n }\n \n }\n \n if(item_best != null)\n {\n box2.Items.add( new int[]{ item_best[0], item_best[1] } );\n box2.ExpandBoxToFit( PointMatrix[ item_best[0] ][ item_best[1] ] );\n box2.ExpandCoordsToFit( item_best[0], item_best[1]);\n \n items_split.remove(index_best);\n }\n }\n \n // return remaining to be reinserted into the tree\n return items_split; \n }", "public void partition();", "public static void window() {\n\n System.out.println(\"# 1\");\n\n List<String> data = Utils.getData();\n Observable.fromIterable(data)\n .window(2)\n .subscribe((windowStream) -> windowStream.subscribe(new MyObserver<>()));\n\n System.out.println(\"# 2\");\n\n Observable.fromIterable(data)\n .window(2, 3)\n .subscribe((windowStream) -> windowStream.subscribe(new MyObserver<>()));\n\n System.out.println(\"# 3\");\n\n Observable.fromIterable(data)\n .window(2, 3, 1)\n .subscribe((windowStream) -> windowStream.subscribe(new MyObserver<>()));\n\n System.out.println(\"# 4\");\n\n Observable.fromIterable(data)\n .window(100, 100, TimeUnit.MICROSECONDS)\n .subscribe((windowStream) -> windowStream.subscribe(new MyObserver<>()));\n\n System.out.println(\"# 5\");\n\n Observable.fromIterable(data)\n .window((emitter) -> emitter.onNext(1))\n .subscribe((windowStream) -> windowStream.subscribe(new MyObserver<>()));\n\n /*\n Mose of the window operators are similar to buffer.\n */\n }", "private void updateTrimData() {\n\t\tupdateLeftTrimData();\r\n\t\tupdateRightTrimData();\r\n\t}", "private int trimShiftGraph (ArrayList shiftGraph)\n {\n int lastNullIndex = 0;\n boolean foundEndingNonNull =false; // this will be index of first non-null to trim to\n\n for (int i = 0; i < maxPeriodLength; i++)\n {\n if (i >= shiftGraph.size())\n lastNullIndex = i;\n\n // mark the index of the last null we've encounterd as long as we haven't reached trim\n // end point.\n else if ( shiftGraph.get (i) == null && foundEndingNonNull == false)\n lastNullIndex = i;\n\n // if we've found a null already, then the next non null ends our search for trim point\n else if (shiftGraph.get (i) != null && lastNullIndex > 0)\n foundEndingNonNull = true;\n }\n\n // if no nulls, cannot trim return.\n if (lastNullIndex == 0)\n return 0;\n else if (lastNullIndex >= shiftGraph.size() - 1)\n shiftGraph.clear();\n else\n {\n for (int j = 0; j <= lastNullIndex; j++)\n shiftGraph.remove (0);\n }\n\n return lastNullIndex;\n }", "private static void moveWindow() {\n // sort the window array\n int[] windowInstance = window.clone();\n Arrays.sort(windowInstance);\n // use median to update distance readings\n prevDist = dist;\n dist = windowInstance[windowInstance.length / 2];\n // shift window by 1 sample, newest sample at the end \n for (int i = 0; i < window.length - 1; i++) {\n window[i] = window[i + 1];\n }\n window[window.length - 1] = readUsDistance();\n // for testing purpose:\n //System.out.println(Arrays.toString(windowInstance) + \" median: \" + dist);\n }", "public void visiualizeSkipList(){\r\n\t\tint number=0;\r\n\t\tNode dummy = sl.getFrom(0,0);\r\n\t\t\r\n\t\tNode next;\r\n\t\tfor(int i=sl.height(); i>=0; i--){\r\n\t\t\t\r\n\t\t\tnext = sl.getFrom(i,0);\r\n\t\t\t\r\n\t\t\tfor(int j=0; j<(sl.size()+2); j++){\r\n\r\n\t\t\t\tnumber = next.getKey();\r\n\t\t\t\t//F.p(number);\r\n\t\t\t\tif(number==dummy.getKey()){\r\n\r\n\t\t\t\t\tif(number==minf)\r\n\t\t\t\t\t\tSystem.out.print(\"-inf\");\r\n\t\t\t\t\telse if(number==inf)\r\n\t\t\t\t\t\tSystem.out.print(\"---inf\");\r\n\t\t\t\t\telse\r\n\t\t\t\t\tSystem.out.print(repeatStr(\"-\",2)+number);\r\n\t\t\t\t}\r\n\t\t\t\telse\r\n\t\t\t\t\tSystem.out.print(repeatStr(\"-\",4));\r\n\t\t\t\t\r\n\t\t\t\tif(dummy.getKey()==number)\r\n\t\t\t\t\tnext = next.getRight();\r\n\t\t\t\t\r\n\t\t\t\tdummy = dummy.getRight();\r\n\t\t\t}\r\n\t\t\tdummy = sl.getFrom(0,0);\r\n\t\t\tSystem.out.println();\r\n\t\t}\r\n\t}", "private static void skipByExample(List<Integer> numbers) {\n\t\tList<Integer> skippedNumbers = numbers.stream().skip(5).collect(Collectors.toList());\r\n\t\tint fifthNumber = numbers.stream().skip(5 - 1).findFirst().orElse(0);\r\n\t\tList<Integer> firstFiveNumber = numbers.stream().limit(5).collect(Collectors.toList());\r\n\t\tSystem.out.println(skippedNumbers); // Output: [6, 7, 8, 9, 10]\r\n\t\tSystem.out.println(\"5th number = \" + fifthNumber);\r\n\t\tSystem.out.println(\"Limit of 5 number = \" + firstFiveNumber);\r\n\t}", "public List<List<RecordBean>> splitRecordBeansIgnoreTimeStamp(List<RecordBean> recordBeans){\n List<List<RecordBean>> splitRecordBeans = chopped(recordBeans, 10);\n // System.out.println(splitRecordBeans); // prints \"[[5, 3, 1], [2, 9, 5], [0, 7]]\"\n return splitRecordBeans;\n }", "@Override\n public void bindHorizontalList(SpacingSpecData<Integer> data) {\n Context context = mRoot.getContext();\n int contentSizePx = mSpacingSpec.getContentSizePx(context, data);\n LinearLayout.LayoutParams rootParams = new LinearLayout.LayoutParams(ViewGroup.LayoutParams.MATCH_PARENT, contentSizePx);\n rootParams.setMargins(0, mSpacingSpec.getPaddingPx(context), 0, mSpacingSpec.getPaddingPx(context));\n mRoot.setLayoutParams(rootParams);\n RecyclerView horizontalList = new RecyclerView(context);\n horizontalList.setLayoutParams(new LinearLayout.LayoutParams(ViewGroup.LayoutParams.MATCH_PARENT, contentSizePx));\n horizontalList.setClipToPadding(false);\n horizontalList.setPadding(mSpacingSpec.getMarginPx(context), 0, mSpacingSpec.getMarginPx(context), 0);\n horizontalList.setLayoutManager(new LinearLayoutManager(context, LinearLayoutManager.HORIZONTAL, false));\n horizontalList.setAdapter(new HorizontalSquareViewAdapter(data, contentSizePx, mSpacingSpec.getPaddingPx(context)));\n mRoot.addView(horizontalList);\n }", "public interface WindowedDataExtractor {\n public List<Map<String, Double>> extract(List<List<Map<String, AnalysisContainer>>> allWindowedData);\n}", "@Override\n public Spliterator<SampleDescriptor> trySplit() {\n Spliterator<SampleDescriptor> retVal;\n // If there is only one sample left we don't split.\n int remaining = this.samples.size() - this.pos;\n if (remaining <= 1)\n retVal = null;\n else {\n // Compute the size for the entire list. This will be our running total of the size of the\n // remaining samples.\n long total = this.length();\n // Set up the new list.\n List<SampleDescriptor> newList = new ArrayList<SampleDescriptor>(remaining - 1);\n long newTotal = 0;\n // Loop until the old list is almost empty or it is smaller or equal to the new list, moving samples\n // from the end of the old list to the beginning of the new list.\n for (int tail = this.samples.size() - 1; tail > this.pos && newTotal < total; tail--) {\n // Move the last element in the old list to the new list.\n SampleDescriptor popped = this.samples.remove(tail);\n newList.add(popped);\n // Adjust the lengths.\n long len = popped.estimatedSize();\n total -= len;\n newTotal += len;\n }\n // Create a spliterator from the new list.\n retVal = new Splitter(newList);\n }\n return retVal;\n }", "private static List<Point> createIncreasingDecreasingDataset() {\r\n List<Point> data = new ArrayList<Point>();\r\n add(data, 1, 400);\r\n add(data, 5, 700);\r\n add(data, 10, 900);\r\n add(data, 15, 1000);\r\n add(data, 20, 900);\r\n add(data, 25, 700);\r\n add(data, 30, 500);\r\n return data;\r\n }", "public static LinkedList<Integer> copyR(ArrayList<Integer> orig, int start, LinkedList<Integer> myList) {\n if(orig.size() == 0 || start >= orig.size()) {\n return myList;\n } else {\n //if bigger, add the element at start into the LinkedList INCLUDE IN RETURN\n myList.addLast(orig.get(start));\n return copyR(orig, start + 1, myList);\n }\n }", "public static void smoothContour(List<PointIndex_I32> v, int minLength) {\n if(v.size() > 0){\n //if the distance between any two sequential points is < minLength, remove that point\n for (int i = v.size() - 2; i >= 0; i--) {\n if (v.get(i).distance(v.get(i + 1)) < minLength) {\n v.remove(i + 1);\n }\n }\n //test the distance between the last point and the first\n if (v.get(v.size() - 1).distance(v.get(0)) < minLength) {\n v.remove(v.size() - 1);\n }\n }\n }", "private static <T> List<List<T>> getSubsets( int indexToStart, int subSize, List<T> toClone, List<T> origList ) {\n List<List<T>> allSubsets = new ArrayList<List<T>>();\n for ( int i = indexToStart; i <= origList.size() - subSize; i++ ) {\n List<T> subset = new ArrayList<T>( toClone );\n subset.add( origList.get( i ) );\n if ( subSize == 1 ) {\n allSubsets.add( subset );\n } else {\n allSubsets.addAll( getSubsets( i + 1, subSize - 1, subset, origList ) );\n }\n }\n return allSubsets;\n }", "private XYChart.Series<String, Double> resizeDataSeries(XYChart.Series<String, Double> series) {\n int adjustedNumPoints = MAX_DATA_POINTS - 2;\n int adjustedLength = series.getData().size() - 2;\n double divisor = adjustedLength - adjustedNumPoints + 1;\n double removeEvery = adjustedLength / divisor;\n double indexSum = removeEvery;\n int[] skippedIndices = new int[adjustedLength - adjustedNumPoints];\n int skippedIndex = (int) Math.ceil(indexSum);\n int i = 0;\n\n XYChart.Series<String, Double> resizedSeries = new XYChart.Series<>();\n XYChart.Data<String, Double> first = series.getData().get(0);\n XYChart.Data<String, Double> last = series.getData().get(series.getData().size() - 1);\n\n series.getData().remove(0);\n series.getData().remove(series.getData().size() - 1);\n resizedSeries.getData().add(first);\n\n while (skippedIndex < adjustedLength) {\n skippedIndices[i] = skippedIndex;\n indexSum += removeEvery;\n skippedIndex = (int) Math.ceil(indexSum);\n i += 1;\n }\n\n i = 0;\n skippedIndex = skippedIndices[i];\n\n for (int j = 0; j < series.getData().size(); j++) {\n if (j != skippedIndex) {\n resizedSeries.getData().add(series.getData().get(j));\n } else if (i < skippedIndices.length - 1) {\n i += 1;\n skippedIndex = skippedIndices[i];\n }\n }\n\n resizedSeries.getData().add(last);\n\n return resizedSeries;\n }", "private void trimListsToSize() {\n\t\tif (geneNames instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneNames).trimToSize();\n\t\t}\n\t\tif (geneNameOffsets instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneNameOffsets).trimToSize();\n\t\t}\n\t\tif (geneStrands instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneStrands).trimToSize();\n\t\t}\n\t\tif (geneStarts instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneStarts).trimToSize();\n\t\t}\n\t\tif (geneStops instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneStops).trimToSize();\n\t\t}\n\t\tif (geneUTR5Bounds instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneUTR5Bounds).trimToSize();\n\t\t}\n\t\tif (geneUTR3Bounds instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneUTR3Bounds).trimToSize();\n\t\t}\n\t\tif (exonOffsets instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) exonOffsets).trimToSize();\n\t\t}\n\t\tif (geneScores instanceof PrimitiveList<?>) {\n\t\t\t((PrimitiveList<?>) geneScores).trimToSize();\n\t\t}\n\t}", "@Override\n public void resetFilteredLists() {\n\n }", "@Nonnull \r\n\tpublic static <T> CloseableIterable<List<T>> chunkify(\r\n\t\t\t@Nonnull Observable<? extends T> source) {\r\n\t\treturn collect(\r\n\t\t\t\tsource,\r\n\t\t\t\tnew Func0<List<T>>() {\r\n\t\t\t\t\t@Override\r\n\t\t\t\t\tpublic List<T> invoke() {\r\n\t\t\t\t\t\treturn new ArrayList<T>();\r\n\t\t\t\t\t}\r\n\t\t\t\t},\r\n\t\t\t\tnew Func2<List<T>, T, List<T>>() {\r\n\t\t\t\t\t@Override\r\n\t\t\t\t\tpublic List<T> invoke(List<T> param1, T param2) {\r\n\t\t\t\t\t\tparam1.add(param2);\r\n\t\t\t\t\t\treturn param1;\r\n\t\t\t\t\t}\r\n\t\t\t\t},\r\n\t\t\t\tnew Func1<List<T>, List<T>>() {\r\n\t\t\t\t\t@Override\r\n\t\t\t\t\tpublic List<T> invoke(List<T> param) {\r\n\t\t\t\t\t\treturn new ArrayList<T>();\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t);\r\n\t}", "private DataStructure copyAndCut (int min, int max, boolean axis){\r\n\t\tDataStructure newDS = new DataStructure();\r\n\t\tPoint[] regAxis = getPointsInRangeRegAxis(min, max, axis); //O(n)\r\n\t\tPoint[] oppAxis = getPointsInRangeOppAxis(min, max, axis); //O(n)\r\n\t\t\r\n\t\tfor(int i=0; i<regAxis.length ; i++)\r\n\t\t\tnewDS.naiveAddLast(regAxis[i], axis); //O(1) * n times\r\n\t\t\r\n\t\tfor(int i=0; i<oppAxis.length ; i++)\r\n\t\t\tnewDS.naiveAddLast(oppAxis[i], !axis); //O(1) * n times\r\n\t\t\r\n\t\treturn newDS;\r\n\t}", "public void mondrian(ArrayList<double[]> data){\n\t\t\n\t\t/*\n\t\t* check if it is possible to split the partition again that is by checking if \n\t\t* k-Anonymity is still guaranteed after this cut by checking if the amount of \n\t\t* individuals in the new partitions is k ore more\n\t\t*/\n\t\tif(data.size() >= 2*k){\n\t\t\tcluster(data);\n\t\t}\n\t\t// if there are not enough elements left, we anonymize the data\n\t\telse{\n\t\t\tanonymize(data);\n\t\t}\n\t}", "public MedianFinder1() {\n list = new ArrayList<>();\n }", "public native RecordList getRangeAsRecordList(int start, int end) /*-{\r\n var self = [email protected]::getOrCreateJsObj()();\r\n var recordsJS = self.getRange(start, end);\r\n return (recordsJS == null || recordsJS === undefined) ? null :\r\n @com.smartgwt.client.data.RecordList::new(Lcom/google/gwt/core/client/JavaScriptObject;)(recordsJS);\r\n }-*/;", "protected void trimToSize() {\n\tnodeList.trimToSize();\n\tedgeList.trimToSize();\n }", "@Test\n\tpublic void windowWillAccumulateMultipleListsOfValues() {\n\t\tSinks.Many<Integer> numbers = Sinks.many().multicast().onBackpressureBuffer();\n\n\t\t//non overlapping buffers\n\t\tSinks.Many<Integer> boundaryFlux = Sinks.many().multicast().onBackpressureBuffer();\n\n\t\tStepVerifier.create(numbers.asFlux()\n\t\t\t\t\t\t\t\t .window(boundaryFlux.asFlux())\n\t\t\t\t\t\t\t\t .concatMap(Flux::buffer)\n\t\t\t\t\t\t\t\t .collectList())\n\t\t\t\t\t.then(() -> {\n\t\t\t\t\t\tnumbers.emitNext(1, FAIL_FAST);\n\t\t\t\t\t\tnumbers.emitNext(2, FAIL_FAST);\n\t\t\t\t\t\tnumbers.emitNext(3, FAIL_FAST);\n\t\t\t\t\t\tboundaryFlux.emitNext(1, FAIL_FAST);\n\t\t\t\t\t\tnumbers.emitNext(5, FAIL_FAST);\n\t\t\t\t\t\tnumbers.emitNext(6, FAIL_FAST);\n\t\t\t\t\t\tnumbers.emitComplete(FAIL_FAST);\n\t\t\t\t\t\t//\"the collected lists are available\"\n\t\t\t\t\t})\n\t\t\t\t\t.assertNext(res -> assertThat(res).containsExactly(Arrays.asList(1, 2, 3), Arrays.asList(5, 6)))\n\t\t\t\t\t.verifyComplete();\n\t}", "@JsIgnore\n @Override\n public void removeRowData(int firstRowIndex, int count) {\n int tmpCount = count;\n while (tmpCount > 0) {\n int amount = Math.min(tmpCount, 10);\n tmpCount -= amount;\n super.removeRowData(firstRowIndex + tmpCount, amount);\n }\n }", "public void MedianFinder() {\n lowerPart = new PriorityQueue<>((a, b) -> (b - a));\n higherPart = new PriorityQueue<>();\n count = 0;\n }", "public static <T> Map<Integer, List<T>> paginate(List<T> originalList, int chunkSize) {\n Map<Integer, List<T>> chunks = new LinkedHashMap<>();\n List<List<T>> listOfChunks = new ArrayList<>();\n\n for (int i = 0; i < originalList.size() / chunkSize; i++) {\n listOfChunks.add(originalList.subList(i * chunkSize, i * chunkSize + chunkSize));\n }\n\n if (originalList.size() % chunkSize != 0) {\n listOfChunks.add(originalList.subList(originalList.size() - originalList.size() % chunkSize, originalList.size()));\n }\n\n for (int i = 0; i < listOfChunks.size(); i++) {\n chunks.put(i, listOfChunks.get(i));\n }\n\n return chunks;\n }", "public abstract boolean prependVisibleItems(int i, boolean z);", "private void trimWhitespaces() {\n \n while(currentIndex < dataLength && Character.isWhitespace( data[currentIndex] )) {\n ++currentIndex;\n }\n }", "private int skipTrialingWhite( List content, int start) {\r\n int size = content.size();\r\n if (start > size) {\r\n start = size;\r\n }\r\n\r\n int index = start;\r\n if (currentFormat.trimAllWhite\r\n || currentFormat.textNormalize\r\n || currentFormat.textTrim) {\r\n while( index >= 0) {\r\n if ( !isAllWhitespace( content.get(index - 1)))\r\n break;\r\n --index;\r\n }\r\n }\r\n return index;\r\n }", "public synchronized Measurement[] consumeWindow(){\n Measurement[] m=new Measurement[windowSize];\n double mean=0;\n /*\n Checking if there are enough items to be consumed is a synchronized operation.\n */\n while(toBeConsumed<windowSize){\n //System.out.println(\"Not enough value\");\n try{\n wait();\n }\n catch (InterruptedException e){\n System.out.println(\"The thread was teared down\");\n }\n }\n //System.out.println(\"Consumer woke up\");\n for(int i=0;i<windowSize;i++)\n m[i]=buf[(startIdx+i)%size];\n\n /*\n Updating values of toBeConsumed is a synchronized operation. Notify to the producer that the buffer\n is no more full.\n */\n /*\n 50% overlap\n */\n toBeConsumed-=windowSize/2;\n notifyAll();\n /*\n Shift the window forward\n */\n startIdx=(startIdx+windowSize/2)%size;\n return m;\n }", "private List<ReducedContainer> toReduced(){\n List<ReducedContainer> reduced = new ArrayList<>();\n for(SpecialContainer specialContainer: specialContainers){\n reduced.add(new ReducedContainer(specialContainer.getType(), specialContainer.getCount()));\n }\n\n return reduced;\n\n }", "public List<List<RecordBean>> splitRecordBeans(List<RecordBean> recordBeans){\n\n recordBeans.sort(RecordBeanComparator);\n List<List<RecordBean>> totalList = new ArrayList();\n for (int i = 0; i < recordBeans.size(); i++){\n Time beginTime = getTimeValueFromRecordBean(recordBeans.get(i));\n if(beginTime != null){\n List<RecordBean> tempList = new ArrayList<>();\n tempList.add(recordBeans.get(i));\n for (int j = i+1; j < recordBeans.size(); j++){\n Time currentTime = getTimeValueFromRecordBean(recordBeans.get(j));\n if(currentTime != null){\n long timeDifference = getTimeDifference(beginTime, currentTime);\n if(timeDifference >= 2){\n totalList.add(new ArrayList<>(tempList));\n beginTime = currentTime;\n tempList.clear();\n tempList.add(recordBeans.get(j));\n }else{\n tempList.add(recordBeans.get(j));\n }\n }\n }\n break;\n }\n }\n return totalList;\n }", "public ListUtilities quicksort(){\n\t\t\n\t\tListUtilities lo = this.returnToStart();\n\t\tListUtilities hi = this.goToEnd();\n\t\tListUtilities sorted = this.partition(lo, hi);\n\t\t\n\t\treturn sorted.returnToStart();\t\t\n\t}", "public static List<Double> medianFilter(List<Double> listToFilter, int n) {\r\n \r\n if (n % 2 == 0) {\r\n throw new Error(\"Medianfilter not implemented for even n values\");\r\n }\r\n \r\n List<Double> filteredList = new ArrayList<Double>();\r\n \r\n int numberOfZeroesToAddBefore = (n - 1) / 2;\r\n int numberOfZeroesToAddAfter = (n - 1) / 2;\r\n \r\n for (int i = 0; i < numberOfZeroesToAddBefore; i++) {\r\n listToFilter.add(0, 0.0);\r\n }\r\n for (int i = 0; i < numberOfZeroesToAddAfter; i++) {\r\n listToFilter.add(0.0);\r\n }\r\n \r\n for (int i = numberOfZeroesToAddBefore; i < listToFilter.size() - numberOfZeroesToAddAfter; i++) {\r\n double median = median(new ArrayList<Double>(listToFilter.subList(i - (n / 2), i + (n / 2) + 1)));\r\n filteredList.add(median);\r\n }\r\n \r\n for (int i = 0; i < numberOfZeroesToAddBefore; i++) {\r\n listToFilter.remove(0);\r\n }\r\n for (int i = 0; i < numberOfZeroesToAddAfter; i++) {\r\n listToFilter.remove(listToFilter.size() - 1);\r\n }\r\n return filteredList;\r\n }", "private static void trimLines( List lines ) {\n \n /* Strip any blank lines from the top. */\n for ( ListIterator it = lines.listIterator( 0 ); it.hasNext(); ) {\n String line = (String) it.next();\n if ( line.trim().length() == 0 ) {\n it.remove();\n }\n else {\n break;\n }\n }\n \n /* Strip any blank lines from the bottom. */\n for ( ListIterator it = lines.listIterator( lines.size() );\n it.hasPrevious(); ) {\n String line = (String) it.previous();\n if ( line.trim().length() == 0 ) {\n it.remove();\n }\n else {\n break;\n }\n }\n }", "private List<View> m9533a(List<View> list, List<View> list2) {\n LinkedList linkedList = new LinkedList();\n if (list != null && !list.isEmpty()) {\n int size = list.size();\n for (int i = 0; i < size; i++) {\n linkedList.add(list.get(i));\n }\n }\n if (list2 != null && !list2.isEmpty()) {\n int size2 = list2.size();\n for (int i2 = 0; i2 < size2; i2++) {\n linkedList.add(list2.get(i2));\n }\n }\n return linkedList;\n }", "@Nonnull\r\n\tpublic static <T> Observable<List<T>> buffer(\r\n\t\t\t@Nonnull final Observable<? extends T> source,\r\n\t\t\tfinal int bufferSize,\r\n\t\t\tint skip) {\r\n\t\treturn new Buffer.WithSizeSkip<T>(source, bufferSize, 0);\r\n\t}", "private void trimArray()\r\n\t\t{\r\n\t\t\t\r\n\t\t\tSystem.out.println(\"[INFO] <RADIOBUTTON_PANEL_BUILDER> Running trimArray\");\r\n\t\t\t\r\n\t\t\tJRadioButton[] newArray = new JRadioButton[nextRadioButtonLocation]; // Create a new array of the correct size\r\n\t\t\t\r\n\t\t\tfor (int i = 0; i < nextRadioButtonLocation; i++) // For each object in the array\r\n\t\t\t{\r\n\t\t\t\tnewArray[i] = radioButtons[i]; // Copy the object\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\tradioButtons = newArray; // Store the new trimmed array in components\r\n\t\t}", "static <T> List<List<T>> partition(List<T> list, int size) {\n return new Partition<>(list, size);\n }", "void calculateChevronTrim() {\n ToolBar tb = new ToolBar( parent, SWT.FLAT );\n ToolItem ti = new ToolItem( tb, SWT.PUSH );\n // Image image = new Image (display, 1, 1);\n // ti.setImage (image);\n Point size = tb.computeSize( SWT.DEFAULT, SWT.DEFAULT );\n size = parent.fixPoint( size.x, size.y );\n CHEVRON_HORIZONTAL_TRIM = size.x - 1;\n CHEVRON_VERTICAL_TRIM = size.y - 1;\n tb.dispose();\n ti.dispose();\n // image.dispose ();\n }", "public void metodoDropWhile() {\n List<Dish> slicedMenu2\n = specialMenu.stream()\n .dropWhile(dish -> dish.getCalories() < 320)\n .collect(toList());\n }", "void splitData( List<P> points , @Nullable GrowQueue_I32 indexes ,\n\t\t\t\t\tList<P> left , @Nullable GrowQueue_I32 leftIndexes ,\n\t\t\t\t\tList<P> right , @Nullable GrowQueue_I32 righrIndexes );", "public void shellSort(){\n int increment = list.size() / 2;\n while (increment > 0) {\n for (int i = increment; i < list.size(); i++) {\n int j = i;\n int temp = list.get(i);\n while (j >= increment && list.get(j - increment) > temp) {\n list.set(j, list.get(j - increment));\n j = j - increment;\n }\n list.set(j, temp);\n }\n if (increment == 2) {\n increment = 1;\n } else {\n increment *= (5.0 / 11);\n }\n }\n }", "public void trimToSize();", "protected static List<List<Card>> expandCardSets(List<Set<Card>> cardSets, int minRunSize) {\n // Expand the card sets\n List<List<Card>> runs = new ArrayList<>();\n runs.add(new ArrayList<>());\n for (Set<Card> cardSet : cardSets) {\n runs = multiply(runs, cardSet);\n }\n\n // Pick out appropriate runs.\n List<List<Card>> runsWithMinSize = new ArrayList<>();\n for (List<Card> run : runs) {\n for (int i = run.size(); i >= minRunSize; i--) {\n runsWithMinSize.add(run.subList(0, i));\n }\n }\n return runsWithMinSize;\n }", "protected void stopAndViewToPast()\n {\n if(!widgg.common.bFreeze){ \n widgg.common.bFreeze = true;\n //now ixDataShow remain unchanged.\n } else {\n int ixdDataSpread = ixDataShowRight - ixDataShown[pixelOrg.xPixelCurve * 5/10];\n //int ixDataShowRight1 = ixDataShown[nrofValuesShow * 7/8];\n //int ixdDataSpread = ixDataShowRight - ixDataShowRight1;\n ixDataShowRight -= ixdDataSpread;\n if((ixDataShowRight - widgg.ixDataWr) < 0 && (widgg.ixDataWr - ixDataShowRight) < ixdDataSpread) {\n //left end reached.\n ixDataShowRight = widgg.ixDataWr + ixdDataSpread;\n }\n }\n widgg.redraw(100, 200);\n //System.out.println(\"left-bottom\");\n \n }", "private static List<TimeSeries> splitSeries(TimeSeries series, Duration splitDuration, Duration sliceDuration) {\n ArrayList<TimeSeries> subseries = new ArrayList<>();\n if (splitDuration != null && !splitDuration.isZero() && \n sliceDuration != null && !sliceDuration.isZero()) {\n\n List<Integer> beginIndexes = getSplitBeginIndexes(series, splitDuration);\n beginIndexes.forEach((subseriesBegin) -> {\n subseries.add(subseries(series, subseriesBegin, sliceDuration));\n });\n }\n return subseries;\n }", "public MedianFinder() {\n list = new ArrayList<>();\n }", "private Dataset<Row> takeRowsSecondWay(Dataset<Row> input) {\n\t\t\n\t\tString[] colulmsString = input.columns();\n\t\t\n\t\tfor( int i = 0; i < colulmsString.length; i++) {\n\t\t\t\n\t\t\tif ( !(i >= this.indexFrom && i <= this.indexTo))\n\t\t\t\t// drop column\n\t\t\t\tinput = input.drop(input.col(colulmsString[i]));\n\t\t\n\t\t}\n\t\treturn input;\n\t}", "private void snap(int l) {\n if (l < lowerLimit1) {\n if (l > snapLimit0) {\n hsv.smoothScrollTo((quarterHolderWidth), 0);\n } else {\n hsv.smoothScrollTo(0, 0);\n }\n } else if (l >= lowerLimit1 && l < lowerLimit2) {\n if (l > snapLimit1) {\n hsv.smoothScrollTo((2 * quarterHolderWidth), 0);\n } else {\n hsv.smoothScrollTo((quarterHolderWidth), 0);\n }\n } else if (l >= lowerLimit2 && l < lowerLimit3) {\n if (l > snapLimit2) {\n hsv.smoothScrollTo((3 * quarterHolderWidth), 0);\n } else {\n hsv.smoothScrollTo((2 * quarterHolderWidth), 0);\n }\n } else if (l >= lowerLimit3 && l < lowerLimit4) {\n if (l > snapLimit3) {\n hsv.smoothScrollTo(holderWidth, 0);\n } else {\n hsv.smoothScrollTo((3 * quarterHolderWidth), 0);\n }\n } else if (l >= lowerLimit4) {\n hsv.smoothScrollTo(holderWidth, 0);\n }\n }", "public ListUtilities partition(ListUtilities start, ListUtilities pivot){\n\t\tboolean swap = false;\n\t\tListUtilities lo = start;\n\t\tListUtilities hi = pivot;\n\t\twhile( lo != pivot){\n\t\t\t//System.out.println(\"lo \" + lo.num + \" hi \" + hi.num + \" pivot \" + pivot.num + \" start \" + start.num);\n\t\t\tif(lo.num > pivot.num){\n\t\t\t\tListUtilities next = lo.nextNum;\n\t\t\t\tif(lo == start){\n\t\t\t\t\tstart = next;\n\t\t\t\t}\n\t\t\t\t//if lo is not first\n\t\t\t\tif(lo.prevNum != null){\n\t\t\t\t\t//remove current lo\n\t\t\t\t\tlo.prevNum.nextNum = lo.nextNum;\n\t\t\t\t\tnext.prevNum = lo.prevNum;\n\t\t\t\t}else{\n\t\t\t\t\tnext.prevNum = null;\n\t\t\t\t}\n\t\t\t\t//if hi is not last\n\t\t\t\tif(hi.nextNum != null){\n\t\t\t\t\t//connect with element after current hi\n\t\t\t\t\tlo.nextNum = hi.nextNum;\n\t\t\t\t\thi.nextNum.prevNum = lo;\n\t\t\t\t}else{\n\t\t\t\t\t//connect with element after current hi\n\t\t\t\t\tlo.nextNum = null;\n\t\t\t\t}\n\t\t\t\t//connect with pivot\n\t\t\t\tlo.prevNum = hi;\n\t\t\t\thi.nextNum = lo;\n\n\t\t\t\thi = lo;\n\t\t\t\tlo = next;\n\t\t\t}else{\n\t\t\t\tlo = lo.nextNum;\n\t\t\t}\n\t\t}\n\t\tif(start != pivot.prevNum && start != pivot){\n\t\t\tstart = partition(start, pivot.prevNum);\n\t\t}\n\t\tif(pivot != hi){\n\t\t\tpartition(pivot.nextNum, hi);\n\t\t}\n\t\treturn start;\n\t}", "public void filterByMyMostRece() {\n // for each mood event in the list\n for (int i = 0; i < moodListBeforeFilterMy.getCount(); i++ ){\n // get the mood's date\n dateOfMood = moodListBeforeFilterMy.getMoodEvent(i).getDateOfRecord();\n // if it within the range, then add it to the new list\n if (dateOfMood.compareTo(lowerBoundDATE) >= 0 && dateOfMood.compareTo(currentDATE) <= 0) {\n moodListAfterFilter.add(moodListBeforeFilterMy.getMoodEvent(i));\n }\n }\n }", "public List<LotReportRow> generateReportOnLotsWithMinimumAmount(long minimumAmount, int start, int numOfRows) throws MiddlewareQueryException;", "ProjectionalObservableListSynchronizer(\n Mapper<? extends ContextT, ? extends Cell> mapper,\n ObservableList<SourceItemT> source,\n Cell target,\n List<Cell> targetList,\n MapperFactory<SourceItemT, Cell> factory,\n int numAllowedEmptyLines) {\n super(mapper, source, target, targetList, factory);\n mySource = source;\n myNumAllowedEmptyLines = numAllowedEmptyLines;\n }", "@Override\n public LinkedList filterLargerThan(int length) {\n LinkedList newLinkedList = new LinkedList();\n Node currNode = this.head;\n while(currNode.getNextNode() != null){\n if(currNode.getItem().length() <= length){\n newLinkedList.addNode(currNode.getItem());\n }\n currNode = currNode.getNextNode();\n }\n return newLinkedList;\n }", "public SystemRecord[][] List(ArrayList<SystemRecord> list){\n\t\tif(list == null){\n\t\t\treturn null;\n\t\t}\n\t\telse{\n\t\t\tSystemRecord[][] nlist = new SystemRecord[(int)Math.ceil((double)list.size()/(double)5)][5];\n\t\t\tint i;\n\t\t\tint j = 0;\n\t\t\tint count = 0;\n\t\t\tSystem.out.println(\"length: \" + list.size());\n\t\t\tfor(i = 0 ; i < list.size() ; i++){\n\t\t\t\tif( i < 5 ){\n\t\t\t\t\tnlist[j][i] = (SystemRecord)list.get(i);\n\t\t\t\t\tif(i == 4){\n\t\t\t\t\t\tj++;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\telse{\n\t\t\t\t\tnlist[j][i % 5] = list.get(i);\n\t\t\t\t\tcount++;\n\t\t\t\t\tif( count == 5){\n\t\t\t\t\t\tj++;\n\t\t\t\t\t\tcount = 0;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\t\n\t\t\t}\n\t\t\treturn nlist;\t\n\t\t}\n\t\n\t}", "@Test\n public void testRemoveFromFrontNoResize() {\n //No Resize\n for (int i = 0; i < 9; i++) {\n String input = String.format(\"b0%d\", i);\n list.addToBack(input);\n }\n list.removeFromFront();\n int actualCapacity = ((Object[]) (list.getBackingArray())).length;\n Assert.assertEquals(\"The list resized when removing an element from a list while at capacity\",\n ArrayList.INITIAL_CAPACITY, actualCapacity);\n\n //With Resize\n list.addToBack(\"Filler1\");\n list.addToBack(\"Filler2\");\n list.addToBack(\"Filler3\");\n list.removeFromFront();\n list.removeFromFront();\n list.removeFromFront();\n int newActualCapacity = ((Object[]) (list.getBackingArray())).length;\n Assert.assertEquals(\"The list resized when moving from above to below initial capacity.\",\n ArrayList.INITIAL_CAPACITY * 2, newActualCapacity);\n }", "private void buildPostingList(){\n boolean isEndOfList = false;\n// boolean moveToNextDoc = false;\n ArrayList<Integer> tempList = new ArrayList<>(); // tempList to hold doc wise posting List\n\n while(!isEndOfList){\n boolean skipDoc = false;\n int doc = children.get(0).nextCandidate();\n if(doc == -1) {\n // End of list. No more windows to collect. Exit.\n isEndOfList = true; break;\n }\n int distance = super.getDiskReader().getRetrievedDocToLengthMap().get(doc);\n // Check if doc exists in all other children.\n // If it exists, skip to that Document.\n for(QueryNode child : children){\n /* skipToDoc skips the pointer in child node to the current doc.\n */\n if(!child.skipToDoc(doc)) {\n skipDoc = true;\n break;\n }\n\n }\n if(!skipDoc) {\n /* From here, all nodes have the document. Proceed to calculating number of windows in doc */\n\n tempList.clear();\n tempList.add(doc); //\n tempList.add(0); // doc term frequency. We will update this later.\n int fkid = 0; // doc term frequency tracker\n// int i = startTermIndex+1;\n int minPosIndex = 0; // holds the index of the node which has current minimum Pos\n int minPos = children.get(minPosIndex).nextPos(); // initialize min Pos.\n boolean isEndOfDoc = false;\n while(!isEndOfDoc) {\n if(minPos == -1) break; // End of document. Move to next doc\n for (int i = 0; i < children.size(); i++) {\n int pos = children.get(i).nextPos();\n if(pos == -1){\n isEndOfDoc = true;\n break;\n }\n if (pos < minPos) {\n minPos = pos;\n minPosIndex = i;\n }\n }\n if(isEndOfDoc) break;\n /* Check for window size against min pos */\n for (int i = 0; i < children.size(); i++) {\n int pos = children.get(i).nextPos();\n\n if (pos - minPos < distance) {\n // Valid candidate so far.\n // check if last term.\n if (i == children.size() - 1) {\n tempList.add(children.get(minPosIndex).nextPos());\n fkid++;\n // update all the child node pointers to next position. No double dipping\n for(QueryNode child : children)\n child.updatePos();\n\n\n }\n\n } else {\n // Candidate failed.\n // update minimum position to next pos and repeat process\n children.get(minPosIndex).updatePos();\n minPos = children.get(minPosIndex).nextPos();\n break;\n\n }\n }\n\n }\n\n\n /* The document has been consumed. If the temp List size is > 2, we have collected windows.\n Add them to the posting list.\n */\n if (tempList.size() > 2) {\n tempList.set(1, fkid);\n cqi += fkid;\n postingList.addAll(new ArrayList<>(tempList));\n }\n }\n// if(moveToNextDoc) continue;\n children.get(0).updateToNextDoc();\n }\n }", "private void paginate() {\n List<ItemModel> old = adapter.getItems();\n List<ItemModel> New = new ArrayList<>(addList());\n CardStackCallback callback = new CardStackCallback(old, New);\n DiffUtil.DiffResult result = DiffUtil.calculateDiff(callback);\n adapter.setItems(New);\n result.dispatchUpdatesTo(adapter);\n }", "void deleteMedian () {\n if (fillLength > 0) {\n for (int i = fillLength / 2; i < fillLength - 1; i++) {\n array[i] = array[i + 1];\n }\n array[fillLength - 1] = 0;\n fillLength--;\n }\n }", "public final void testFilterRecordingList() throws Exception\n {\n Vector vect = new Vector();\n\n // JAS parametize this so that I can select different configurations.\n long sdArr[][] = { { 0, 10 }, { 0, 12 }, { 0, 8 }, { -5, 20 }, { -5, 13 }, { -5, 15 }, { -5, -7 }, { 2, 10 },\n { 2, 8 }, { 2, 2 }, { 12, 14 }, { -5, 5 }, { 10, 2 } };\n\n patchArray(sdArr, 100);\n for (int i = 0; i < sdArr.length; i++)\n {\n vect.addElement(new RecordingImplMock(new Date(sdArr[i][0]), sdArr[i][1]));\n }\n RecordingList recordingList = new RecordingListImpl(vect);\n\n // list should contains sdArr.length elements\n RecordingList filtered = recordingList.filterRecordingList(null);\n assertNotNull(\"Shouldn't be null\", filtered);\n assertEquals(\"Recording list element count wrong \", sdArr.length, filtered.size());\n }", "private void reduce(){\n int min;\n //Subtract min value from rows\n for (int i = 0; i < rows; i++) {\n min = source[i][0];\n for (int j = 1; j < cols; j++)\n if(source[i][j] < min) min = source[i][j];\n\n for (int j = 0; j < cols; j++)\n source[i][j] -= min;\n }\n\n //Subtract min value from cols\n for (int j = 0; j < cols; j++) {\n min = source[0][j];\n for (int i = 1; i < rows; i++)\n if(source[i][j] < min) min = source[i][j];\n\n for (int i = 0; i < rows; i++)\n source[i][j] -= min;\n\n }\n }", "public ArrayList<Sighting> filter(ArrayList<Sighting> rawSightings);", "public List<LotReportRow> generateReportOnEmptyLots(int start, int numOfRows) throws MiddlewareQueryException;", "public Point[] nearestPairInStrip(Container container, double width, Boolean axis) {\n\t\tdouble leftGap,rightGap;\n\t\tint minIndex;\n\t\tint numInStrip = 0;\n\t\tthis.current = container;\n\t\tPoint currentData = this.current.getData();\n\t\tif (axis){ \t//width of the strip by axis\n\t\t\t leftGap = currentData.getX() + (width/2);\n\t\t \t rightGap = currentData.getX() - (width/2);}\n\t\telse{ leftGap = container.getData().getY() + (width/2);\n\t\t\t rightGap = container.getData().getY() - (width/2);}\t\n\t\t\n\t\t// we count the number of points in the strip with aid function\n\t\tPoint[] setup = {new Point(0, 0)}; \n\t\tPoint[] strip = NumInStripAxis(container,rightGap,leftGap,axis,setup); // return in strip[0].getX() the num of points in the strip\n\t\tnumInStrip = strip[0].getX(); // number of points in the strip\n\t\tminIndex = numInStrip - strip[0].getY(); // index in the array that we will find the min there, later on\n\t\tPoint[] insert = new Point[numInStrip]; // build array in this size\n\t\t// insert the right points to the array\n\t\tif (numInStrip>=2){\n\t\t\tinsert[0] = new Point(numInStrip, 1); // to insert points to the array we need thus values in [0]\n\t\t\tstrip = NumInStripAxis(container,rightGap,leftGap,axis,insert); // O(numInStrip) - the array is not sorted yet\n\t\t}else return null; // there is less then 2 points in the strip\n\t\t\n\t\t// now we sort the \"strip\" array\t\n\t\tif (numInStrip*Math.log10(numInStrip)/Math.log10(2)<this.size){// sort by O(numInStrip*log(numInStrip))\n\t\t\tif (axis) {Arrays.sort(strip, new CompareY());} // if the strip width is axis x then sort by Y\n\t\t\telse \t {Arrays.sort(strip, new CompareX());}\n\t\t}else{ // sort by O(n)\n\t\t\tint min,max;\n\t\t\tif (axis){//X\n\t\t\t\tif (numInStrip==this.size){\n\t\t\t\t\tmin = this.minx.getData().getX();\n\t\t\t\t\tmax = this.maxx.getData().getX();}\n\t\t\t\telse{// if we don't have this.size points in our strip\n\t\t\t\t\tmin = strip[minIndex].getX();\n\t\t\t\t\tmax = strip[0].getX();} // when we build the array the max point in the axis will be in the 0 index\n\t\t\t}\n\t\t\telse{ //Y\n\t\t\t\tif (numInStrip==this.size){\n\t\t\t\t\tmin = this.miny.getData().getY();\n\t\t\t\t\tmax = this.maxy.getData().getY();}\n\t\t\t\telse{// if we don't have all the data structure in our strip\n\t\t\t\t\tmin = strip[minIndex].getY();\n\t\t\t\t\tmax = strip[0].getY(); // when we build the array the max point in the axis will be in the 0 index\n\t\t\t\t}\n\t\t\t}\n\t\t\tstrip = getPointsInRangeOppAxis(min, max, axis); // O(n) - to sorted this \"strip\" array\n\t\t}\n\t\t// now we want to know which of the points is the nearest points in the \"strip\" array\n\t\tif (strip.length>=2) return nearestPointInArray(strip);\n\t\telse return null;\n\t}", "void example13() {\n\t\t\n\t\t// create a list of zeroes\n\t\t\n\t\tIndexedDataSource<Float64Member> list =\n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.DBL.construct(), 1000);\n\n\t\t// now setup a view that will increment by 3 starting at the list[4] and steps\n\t\t// up to 100 times.\n\t\t\n\t\tIndexedDataSource<Float64Member> seqData =\n\t\t\t\tnew SequencedDataSource<Float64Member>(list, 4, 3, 100);\n\n\t\tseqData.size(); // size == 100\n\t\t\n\t\t// now set a bunch of values\n\t\t\n\t\tFloat64Member value = G.DBL.construct();\n\t\t\n\t\tfor (long i = 0; i < seqData.size(); i++) {\n\t\t\tvalue.setV(i);\n\t\t\tseqData.set(i, value);\n\t\t}\n\t\t\n\t\t// data = [0, 0, 0, 0, 1, 0, 0, 2, 0, 0, 3, 0, 0, 4, 0, 0, 5, 0, 0, ...]\n\t}", "ArrayList<DataObject> dataObjects(Activity activity, ArrayList<Spieler> spieler, ArrayList<ArrayList<Statistikwerte>> statistikwerte){\n\n ArrayList<DataObject> dataObjects = new ArrayList<DataObject>();\n\n for (int i=0; i<spieler.size(); i++){\n Log.d(\"ANZAHL\", String.valueOf(statistikwerte.get(i).size()));\n DataObject dataObject = new DataObject(activity, spieler.get(i), statistikwerte.get(i));\n\n if(i == spieler.size()-1 && spieler.size() > 2){\n View v = dataObject.getDataviews().get(0);\n v.setPadding(v.getPaddingLeft(), v.getPaddingTop(), v.getPaddingRight(), v.getPaddingBottom()+30);\n }\n\n dataObjects.add(dataObject);\n }\n\n\n return dataObjects;\n\n }", "static <T> List<List<T>> chunkList(List<T> list, final int L) {\n\t\tList<List<T>> parts = new ArrayList<List<T>>();\n\t\tfinal int N = list.size();\n\t\t\n\t\tfor (int i = 0; i < N; i += L) {\n\t\t\tparts.add(new ArrayList<T>(\n\t\t\t\t\tlist.subList(i, Math.min(N, i + L)))\n\t\t\t\t\t);\n\t\t}\n\t\t\n\t\treturn parts;\n\t}", "private final void filterList(List<? extends Entity> list) {\n if (!list.isEmpty()) {\n if (getDataList().isEmpty()) {\n getDataList().addAll(0, list);\n return;\n }\n ArrayList arrayList = new ArrayList();\n arrayList.addAll(list);\n for (int size = list.size() - 1; size >= 0; size--) {\n int size2 = getDataList().size() - 1;\n while (true) {\n if (size2 < 0) {\n break;\n }\n String entityId = ((Entity) list.get(size)).getEntityId();\n Parcelable parcelable = getDataList().get(size2);\n Object obj = null;\n if (!(parcelable instanceof Entity)) {\n parcelable = null;\n }\n Entity entity = (Entity) parcelable;\n Intrinsics.checkNotNull(entity);\n if (TextUtils.equals(entityId, entity.getEntityId())) {\n arrayList.remove(list.get(size));\n Long dateline = ((Entity) list.get(size)).getDateline();\n Parcelable parcelable2 = getDataList().get(size2);\n if (!(parcelable2 instanceof Entity)) {\n parcelable2 = null;\n }\n Entity entity2 = (Entity) parcelable2;\n Intrinsics.checkNotNull(entity2);\n if (!Intrinsics.areEqual(dateline, entity2.getDateline())) {\n Object obj2 = list.get(size);\n if (obj2 instanceof Message) {\n obj = obj2;\n }\n Message message = (Message) obj;\n Intrinsics.checkNotNull(message);\n int findNewIndex = findNewIndex(message);\n if (findNewIndex <= -1 || findNewIndex == size2) {\n getDataList().set(size2, list.get(size));\n } else {\n getDataList().add(findNewIndex, list.get(size));\n List<Parcelable> dataList = getDataList();\n int i = size2 + 1;\n if (!(findNewIndex > size2)) {\n size2 = i;\n }\n dataList.remove(size2);\n }\n }\n }\n size2--;\n }\n }\n for (int size3 = arrayList.size() - 1; size3 >= 0; size3--) {\n Object obj3 = arrayList.get(size3);\n Intrinsics.checkNotNullExpressionValue(obj3, \"noExistedData[newListIndex]\");\n Parcelable parcelable3 = (Parcelable) obj3;\n if (parcelable3 instanceof Message) {\n if (((Message) parcelable3).isToped()) {\n getDataList().add(0, parcelable3);\n } else if (findLastTopIndex() <= -1) {\n getDataList().add(findLastTopIndex() + 1, parcelable3);\n }\n }\n }\n }\n }", "public void trimList(Man m) {\n if (list.person == m) {\r\n\t\t\tlist = null;\r\n\t\t} else {\r\n PersonList ls = list;\r\n while (ls.next.person != m) {\r\n\t\t\t\tls = ls.next;\r\n\t\t\t}\r\n ls.next = null; // drop m and all below him\r\n }\r\n }", "@Override\n public void splice(ThreadContext tc, SixModelObject from, long offset, long count) {\n long elems0 = elems;\n long elems1 = from.elems(tc);\n long start;\n long tail;\n double[] slots = null;\n\n /* start from end? */\n if (offset < 0) {\n offset += elems0;\n\n if (offset < 0)\n throw ExceptionHandling.dieInternal(tc, \"VMArray: Illegal splice offset\");\n }\n\n /* When offset == 0, then we may be able to reduce the memmove\n * calls and reallocs by adjusting SELF's start, elems0, and\n * count to better match the incoming splice. In particular,\n * we're seeking to adjust C<count> to as close to C<elems1>\n * as we can. */\n if (offset == 0) {\n long n = elems1 - count;\n start = this.start;\n if (n > start)\n n = start;\n if (n <= -elems0) {\n elems0 = 0;\n count = 0;\n this.start = 0;\n this.elems = (int)elems0;\n }\n else if (n != 0) {\n elems0 += n;\n count += n;\n this.start = (int)(start - n);\n this.elems = (int)elems0;\n }\n }\n\n /* if count == 0 and elems1 == 0, there's nothing left\n * to copy or remove, so the splice is done! */\n if (count == 0 && elems1 == 0)\n return;\n\n /* number of elements to right of splice (the \"tail\") */\n tail = elems0 - offset - count;\n if (tail < 0)\n tail = 0;\n\n else if (tail > 0 && count > elems1) {\n /* We're shrinking the array, so first move the tail left */\n slots = this.slots;\n start = this.start;\n memmove(slots, start + offset + elems1, start + offset + count, tail);\n }\n\n /* now resize the array */\n set_size_internal(tc, offset + elems1 + tail);\n\n slots = this.slots;\n start = this.start;\n if (tail > 0 && count < elems1) {\n /* The array grew, so move the tail to the right */\n memmove(slots, start + offset + elems1, start + offset + count, tail);\n }\n\n /* now copy C<from>'s elements into SELF */\n if (elems1 > 0) {\n int i;\n int from_pos = (int)(start + offset);\n for (i = 0; i < elems1; i++) {\n from.at_pos_native(tc, i);\n slots[from_pos + i] = tc.native_n;\n }\n }\n }", "private void loadList(List<Integer> expectedList) {\n expectedList.clear();\n for (int i = 0; i < Constants.WINDOW_SIZE; i++)\n expectedList.add(i);\n }", "public MedianFinder() {\n datas = new ArrayList<>();\n }", "public void lowerHalf() {\n\t\t// TODO: Implement\n\t\tint sumOfSlotCounts = getSumOfSlotCount()-1;\n\t\tif(sumOfSlotCounts < 0) return;\n\t\t//if(getSlotCount() == 1 && getSumOfSlotCount() == 1) return;\n\t\tint slot = getSlotCount()-1;\n\t\tint beanNumber = getSlotBeanCount(slot)-1;\n\t\tint deleted=0;\n\t\t//System.out.println(\"sumOfCounts: \" + sumOfSlotCounts);\n\t\twhile(deleted < Math.floor(sumOfSlotCounts / 2) ){\n\t\t\t/*if (slotBean.get(slot).isEmpty()) {\n\t\t\t\tslot++;\n\t\t\t\tbeanNumber = 0;\n\t\t\t\tSystem.out.println(\"slot empty: slot: \" + slot + \" beanN: \" + beanNumber);\n\t\t\t}*/\n\t\t\t\n\t\t\t//System.out.println(\"i: \" + deleted + \" count: \" + getSlotBeanCount(slot)+\" beanNumber: \" + beanNumber);\n\t\t\tif(beanNumber < getSlotBeanCount(slot) && beanNumber >= 0 && getSlotBeanCount(slot) > 0 ) {\n\t\t\t\t//System.out.println(\"slot not empty: slot: \" + slot + \" beanN: \" + beanNumber);\n\t\t\t\tslotBean.get(slot).remove(beanNumber--);\n\t\t\t\tdeleted++;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\t//System.out.println(\"slot empty: slot: \" + slot + \" beanN: \" + beanNumber);\n\t\t\t\tif(slot >= 0) slot--;\n\t\t\t\tif(getSlotBeanCount(slot) > 0) beanNumber = getSlotBeanCount(slot)-1;\n\t\t\t\telse beanNumber = 0;\n\t\t\t\t\n\t\t\t}\n\t\t\t\n\t\t}\n\t}", "public Set<String> median(List<Set<String>> inputData) {\n if (inputData == null || inputData.size() == 0) {\n return null; // Cannot do anything\n }\n Collections.sort(inputData, new Comparator<Set<String>>() {\n public int compare(Set<String> set1, Set<String> set2) {\n int size1 = set1.size();\n int size2 = set2.size();\n return size1 - size2;\n }\n });\n // Take the median\n int size = inputData.size();\n int index = size / 2;\n return inputData.get(index);\n }", "public static void AddStripToGrid(ArrayList<ArrayList<Points>> G, ArrayList<Points> strip_temp, double cell_width)\n {\n Collections.sort(strip_temp, new MyComparatorY());\n \n ArrayList<Points> Box = new ArrayList<>(); \n \n for(int i = 0; i < strip_temp.size(); i++)\n {\n ArrayList<Points> q = new ArrayList<>();\n \n q.add(new Points(strip_temp.get(i).x_cor, strip_temp.get(i).y_cor, strip_temp.get(i).p_id, \"no tag\"));\n \n Box.add(new Points(q.get(0).x_cor, q.get(0).y_cor, q.get(0).p_id, q.get(0).tag));\n \n \n int break_flag = 0;\n \n bnm:\n for(int j = i+1; j < strip_temp.size(); j++)\n {\n ArrayList<Points> r = new ArrayList<>();\n \n r.add(new Points(strip_temp.get(j).x_cor, strip_temp.get(j).y_cor, strip_temp.get(j).p_id, \"no tag\"));\n \n double box_dist = (q.get(0).y_cor + cell_Width);\n \n if(r.get(0).y_cor > (q.get(0).y_cor + cell_Width))\n {\n ArrayList<Points> box_temp = new ArrayList<>();\n \n box_temp.addAll(Box);\n \n G.add(box_temp);\n \n break_flag = 1;\n Box.clear();\n \n break bnm;\n }\n \n Box.add(new Points(r.get(0).x_cor, r.get(0).y_cor, r.get(0).p_id, r.get(0).tag));\n \n i=j;\n }\n \n if(break_flag == 0)\n {\n \n ArrayList<Points> box_temp = new ArrayList<>();\n box_temp.addAll(Box);\n\n Box.clear();\n G.add(box_temp);\n } \n }\n }", "private List<Bin> sortCarouselBinsToFront(List<Bin> availableBins, List<String> zoneList) {\r\n List<Bin> sortedBins = new ArrayList<Bin>();\r\n List<Bin> nonCarouselBins = new ArrayList<Bin>();\r\n \r\n for(Bin bin : availableBins) {\r\n if(ObjectUtils.isNotNull(bin.getZone())\r\n && zoneList.contains(bin.getZone().getZoneCd())) {\r\n sortedBins.add(bin);\r\n }\r\n else {\r\n nonCarouselBins.add(bin);\r\n }\r\n }\r\n sortedBins.addAll(nonCarouselBins); \r\n return sortedBins; \r\n }", "@Test\n public void testSubList_Overflow() {\n SegmentedOasisList<Integer> instance = new SegmentedOasisList<>(2, 2);\n Collection c = Arrays.asList(1, 1, 7, 7, 1, 1, 1);\n instance.addAll(c);\n\n List expResult = Arrays.asList(1, 7, 7);\n OasisList<Integer> result = (OasisList<Integer>) instance.subList(1, 4);\n\n assertTrue(isEqual(expResult, result));\n\n }", "public ArrayList<BoardGame> filterByPlayer(ArrayList<BoardGame> list) {\n //int playerCount = Integer.parseInt(numPlayers);\n int playerCount = extractInt(numPlayers);\n ArrayList<BoardGame> tempList = new ArrayList<>();\n for (BoardGame game: list) {\n //Debug print out\n Log.i(\"FILTER PLAYERS\", \"Game: \" + game.getName() + \" Min players: \" + game.getMinPlayers() +\n \" Max players: \" + game.getMaxPlayers() + \" Target players: \" + playerCount);\n //TODO: Is there some case for 10+ that would differ from the below?\n if(game.getMinPlayers() <= playerCount && game.getMaxPlayers() >= playerCount) {\n addGameToList(tempList, game);\n }\n }\n return tempList;\n }", "private void getListRepartition(List list) {\r\n int i;\r\n int id_rep = 1;\r\n Object[] obj;\r\n\r\n this.idNewRep = 1;\r\n this.idNewRepElem = 1;\r\n\r\n for (i = 0; i < list.size(); i++) {\r\n obj = (Object[]) list.get(i);\r\n\r\n // si on change d'id_, on passe à une autre répartition\r\n if (id_rep != Integer.parseInt(obj[3].toString())) {\r\n\r\n id_rep = Integer.parseInt(obj[3].toString());\r\n\r\n this.repartitions.add(new Repartition(Integer.parseInt(obj[3].toString()), obj[0].toString(), this.idAxe));\r\n // System.out.println(\"Axe : \" + this.idAxe + \"Repartition \" + obj[0].toString());\r\n this.ligneRepartitions.add(String.valueOf(this.repartitions.size() - 1));\r\n\r\n if (id_rep > this.idNewRep) {\r\n this.idNewRep = id_rep;\r\n }\r\n\r\n }\r\n\r\n this.repartitionElements.add(new RepartitionElement(Integer.parseInt(obj[4].toString()), Integer.parseInt(obj[3].toString()), Integer.parseInt(obj[2].toString()), Float.parseFloat(obj[1]\r\n .toString())));\r\n\r\n if (Integer.parseInt(obj[3].toString()) > this.idNewRepElem) {\r\n this.idNewRepElem = Integer.parseInt(obj[3].toString());\r\n }\r\n }\r\n }" ]
[ "0.61843914", "0.51134884", "0.5041306", "0.50177145", "0.49958894", "0.4973042", "0.49693674", "0.4968622", "0.49548206", "0.49110103", "0.48884103", "0.47957245", "0.47720277", "0.47435382", "0.47322425", "0.4685629", "0.46764916", "0.46754953", "0.46593723", "0.46498787", "0.4633503", "0.46162555", "0.46073785", "0.45695943", "0.45664465", "0.45408183", "0.45363432", "0.45292544", "0.45282814", "0.4512264", "0.4494188", "0.4488647", "0.44725683", "0.4444488", "0.4434452", "0.4422132", "0.44097745", "0.4408702", "0.43857667", "0.43797547", "0.43691334", "0.43672928", "0.4364166", "0.436371", "0.43627214", "0.43610114", "0.43591434", "0.43576166", "0.4355118", "0.434474", "0.433632", "0.4335068", "0.43346754", "0.43267435", "0.43236032", "0.43161422", "0.43117896", "0.43105343", "0.43036342", "0.43006647", "0.42931736", "0.42923418", "0.429015", "0.42850184", "0.42828956", "0.42767176", "0.42733753", "0.4253678", "0.4253603", "0.4249534", "0.42452294", "0.42342427", "0.42339805", "0.42339382", "0.42259634", "0.42237112", "0.422198", "0.42149574", "0.42130902", "0.42074233", "0.41969144", "0.41968402", "0.4194362", "0.41930184", "0.41893756", "0.41863528", "0.41862842", "0.4185645", "0.41793832", "0.417686", "0.4176174", "0.4172208", "0.41708964", "0.41677216", "0.41664356", "0.41639683", "0.41564825", "0.41505873", "0.41484612", "0.41477638" ]
0.70310485
0
WriteNotifyingDataSource Make a list that notifies listeners every time it stores a value
void example16() { // allocate 10,000 float16's IndexedDataSource<Float16Member> origData = nom.bdezonia.zorbage.storage.Storage.allocate(G.HLF.construct(), 10000); // wrap a notifier around it WriteNotifyingDataSource<Float16Algebra, Float16Member> observedData = new WriteNotifyingDataSource<>(G.HLF, origData); // observe the process observedData.subscribe(new DataSourceListener<Float16Algebra, Float16Member>() { private long lastPercent = -1; @Override public void notify(Float16Algebra alegbra, IndexedDataSource<Float16Member> source, long index) { long cutoff = source.size() / 100; long percent = index / cutoff; if (index >= source.size()-1) { percent = 100; } if (percent != lastPercent) { System.out.println("Operation is " + lastPercent + "done."); lastPercent = percent; } } }); // do the fill: we'll get a bunch of status updates Float16Member value = new Float16Member(1234); Fill.compute(G.HLF, value, observedData); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public List<PersistRequestBean<?>> listenerNotify() {\n return listenerNotify;\n }", "public void notifyState() {\n\t\tList<T> alldata = new ArrayList<T>(this.dataMap.values());\t\r\n\t\t// call them with the current data\r\n\t\t// for each observer call them\r\n\t\tfor( ModelEvents<T> observer : this.ObserverList){\r\n\t\t\tobserver.dataState(alldata);\r\n\t\t}\r\n\r\n\t}", "void notifyWrite();", "@Test\r\n public void testListPropertyNotificationMultipleListener() {\r\n ObservableList<String> initialValue = createObservableList(false);\r\n ListProperty<String> property = new SimpleListProperty<>(initialValue);\r\n ChangeReport report = new ChangeReport(property);\r\n ChangeReport otherListener = new ChangeReport(property);\r\n ObservableList<String> otherValue = createObservableList(false);\r\n assertTrue(\"sanity: FXCollections returns a new instance\", otherValue != initialValue);\r\n property.set(otherValue);\r\n assertEquals(1, report.getEventCount());\r\n assertSame(initialValue, report.getLastOldValue());\r\n assertSame(otherValue, report.getLastNewValue());\r\n }", "@Override\r\n\tpublic void notifyObservers() {\n\t\tfor(Observer o : list) {\r\n\t\t\t// Atualiza a informacao no observador\r\n\t\t\to.update(this, this);\r\n\t\t}\r\n\t}", "@Override\n public void notifyObserver() {\n for(Observer o:list){\n o.update(w);\n }\n }", "public void notifyListeners() {\n Logger logger = LogX;\n logger.d(\"notifyListeners: \" + this.mListeners.size(), false);\n List<IWalletCardBaseInfo> tmpCardInfo = getCardInfo();\n Iterator<OnDataReadyListener> it = this.mListeners.iterator();\n while (it.hasNext()) {\n it.next().refreshData(tmpCardInfo);\n }\n }", "private void notifyObservers() {\n\t\tfor (Observer observer : subscribers) {\n\t\t\tobserver.update(theInterestingValue); // we can send whole object, or just value of interest\n\t\t\t// using a pull variant, the update method will ask for the information from the observer\n\t\t\t// observer.update(this)\n\t\t}\n\t}", "protected void notifyCreated(List<T> objects){\n\t\tfor( ModelEvents<T> observer : this.ObserverList){\r\n\t\t\tobserver.dataCreated(objects);\r\n\t\t}\r\n\t}", "private void notifyListeners() \n\t{\n\t\tSystem.out.println(\"Event Source: Notifying all listeners\");\n\n\t\tfor(IListener listener : listeners)\n\t\t{\n\t\t\tlistener.eventOccured(new Event(this));//passing and object of source\n\t\t}\n\n\t}", "public List<String> listeners();", "private void notifyListeners(boolean dataChanged) {\n for (OnDataChangedListener listener : dataChangedListeners) {\n listener.onDataChanged(dataChanged);\n }\n }", "@Override\n public void notifyObservers() {\n for (Observer observer : observers){\n // observers will pull the data from the observer when notified\n observer.update(this, null);\n }\n }", "private void notifyListeners() {\n\t\tfor(ModelListener l:listeners) {\n\t\t\tl.update();\t// Tell the listener that something changed\n\t\t}\n\t}", "private void notifyEventListListeners() {\n this.eventListListeners.forEach(listener -> listener.onEventListChange(this.getEventList()));\n }", "public void notifyAdapters();", "void notifyAvailableStorageListeners(final int highWaterValue)\n {\n final CallerContextManager ccm = (CallerContextManager) ManagerManager.getInstance(CallerContextManager.class);\n\n if (ccList != null)\n {\n final int lastHighWaterValue = persistentStorageUse;\n ccList.runInContext(new Runnable()\n {\n public void run()\n {\n synchronized (implObject)\n {\n Vector listeners;\n if ((listeners = getCCData(ccm.getCurrentContext()).asListeners) != null)\n {\n // Invoke listeners\n for (int i = 0; i < listeners.size(); i++)\n {\n // we only invoke a listener once for a high\n // water mark value. Listener A\n // wants to be notified at 75% full and listener\n // B wants to be notified at 90% full.\n // So when we hit 80% full, the listener A is\n // notified. On the next write we\n // hit 90% full, only listener B is notified.\n ListenerData ld = (ListenerData) listeners.elementAt(i);\n if (ld.highWaterMark <= highWaterValue)\n {\n if (ld.highWaterMark > lastHighWaterValue)\n {\n ld.listener.notifyHighWaterMarkReached();\n }\n }\n else\n {\n // listeners are inserted in ascending order\n // so we don't have\n // to iterate the whole list.\n break;\n }\n }\n }\n }\n }\n });\n }\n }", "@Test\r\n public void testListPropertyNotificationSingleListener() {\r\n ObservableList<String> initialValue = createObservableList(false);\r\n ListProperty<String> property = new SimpleListProperty<>(initialValue);\r\n ChangeReport report = new ChangeReport(property);\r\n ObservableList<String> otherValue = createObservableList(false);\r\n assertTrue(\"sanity: FXCollections returns a new instance\", otherValue != initialValue);\r\n property.set(otherValue);\r\n assertEquals(1, report.getEventCount());\r\n assertSame(initialValue, report.getLastOldValue());\r\n assertSame(otherValue, report.getLastNewValue());\r\n }", "public void notifyObserver() {\n\r\n for (Observer observer : observers) {\r\n\r\n observer.update(stockName, price);\r\n\r\n }\r\n }", "@Override\n\tpublic void setUpdateData(Collection<FinanceData> updateDataList, \n\t\t\tMap<String,Boolean> notifyList, String currentUser) {\n\t\tthis.notifyList.clear();\n\t\t\n\t\tif (list_fr.isEmpty()) {\n\t\t\tscrollpanel.remove(panel);\n\t\t\tscrollpanel.add(cellTable);\n\t\t}\n\t\t\n\t\tfor (FinanceData data : updateDataList) {\n\t\t\tboolean isexist = false;\n\t\t\tLong id = data.getRequest_id();\n\t\t\tFinanceData notifydata = null;\n\t\t\tif (data.getStatus().equals(\"PENDING\")\n\t\t\t\t\t|| data.getStatus().equals(\"APPROVED\")\n\t\t\t\t\t|| data.getStatus().equals(\"DENIED\")) {\n\t\t\t\tfor (FinanceData olddata : list_fr)\n\t\t\t\t\tif (olddata.getRequest_id().equals(id)) {\n\t\t\t\t\t\tisexist = true;\n\t\t\t\t\t\tif(data.getVersion() != olddata.getVersion()) {\n\t\t\t\t\t\t\tlist_fr.remove(olddata);\n\t\t\t\t\t\t\tlist_fr.add(0, data);\n\t\t\t\t\t\t\tnotifydata = data;\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\tnotifydata = olddata;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\tif(!isexist) {\n\t\t\t\t\tlist_fr.add(0, data);\n\t\t\t\t\tnotifydata = data;\n\t\t\t\t}\n\t\t\t\tString notifyid = String.valueOf(notifydata.getRequest_id());\n\t\t\t\tif(notifyList.containsKey(String.valueOf(notifyid))) {\n\t\t\t\t\tif(notifyList.get(String.valueOf(notifyid)))\n\t\t\t\t\t\tthis.notifyList.add(notifydata);\n\t\t\t\t\telse\n\t\t\t\t\t\tlistener.flushData(notifydata);\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (data.getStatus().equals(\"DRAFT\")) {\n\t\t\t\tfor (FinanceData oldfr : list_fr)\n\t\t\t\t\tif (oldfr.getRequest_id().equals(id))\n\t\t\t\t\t\tlist_fr.remove(oldfr);\n\t\t\t\tif(!data.getReporter().equals(currentUser))\n\t\t\t\t\tlistener.flushData(data);\n\t\t\t}\n\t\t\tif(data.getStatus().equals(\"DELETED\")) {\n\t\t\t\tfor (FinanceData oldfr : list_fr)\n\t\t\t\t\tif (oldfr.getRequest_id().equals(id))\n\t\t\t\t\t\tlist_fr.remove(oldfr);\n\t\t\t\tlistener.flushData(data);\n\t\t\t}\n\t\t}\n\t\t\n\t\tredrawTable();\n\t\tlistener.onRefreshComplete();\n\t}", "@Override\r\n\tpublic void notifyObservers() {\n\t\t\r\n\t}", "private void notifyObservers() {\n BinStatusUpdate newStatus = buildNewStatus();\n observers.iterator().forEachRemaining(binStatusUpdateStreamObserver -> binStatusUpdateStreamObserver.onNext(newStatus));\n }", "void storeEvents()\n {\n this.storedPresences = new ArrayList<Presence>();\n this.storeEvents = true;\n }", "@Override\n\tpublic void onDataChanged()\n\t{\n\t\tfor (DataChangedCallbacks listener : this.dataChangedListeners)\n\t\t{\n\t\t\tlistener.onDataChanged();\n\t\t}\n\t}", "public interface NotificationDataSource {\n Observable<List<Notification>> getNotifications();\n}", "public void notifyObservers() {}", "public interface PieDataListener {\n\n public ArrayList<PieData> getPieData();\n\n public void setPieData(ArrayList<PieData> pieData);\n\n}", "protected abstract List<String> writeData(T property);", "public interface Listener{\n\t\tpublic void notify(Map<String,Serializable> datas);\n\t}", "public void setData(List<Event> data) {\n this.data = data;\n }", "public abstract void write(List<EmitterSystemState> data)\n\t\t\tthrows FailedToWriteToDatastoreException;", "public void notifyObservers();", "public void notifyObservers();", "public void notifyObservers();", "void notifyObservers();", "void notifyObservers();", "public void notifyListeners() {\n Handler handler = new Handler(Looper.getMainLooper()); // TODO reuse\n // handler\n Runnable runnable = new Runnable() {\n\n @Override\n public void run() {\n synchronized (listeners) {\n for (IContentRequester requester : listeners) {\n requester.contentChanged(Content.this);\n }\n }\n }\n };\n boolean success = handler.post(runnable);\n if (success) {\n // Log.d(TAG,\n // \"Posted notification for all listeners from \"+this.toString()+\" to \"+listeners.size()+\" listeners.\");\n Log.d(TAG, \"Posted notification for all listeners from content id \"\n + id + \" to \" + listeners.size() + \" listeners.\");\n } else {\n Log.e(TAG, \"Failed to post notification for all listeners\");\n }\n }", "public interface IDataListener<T> {\n void attach(List<T> objects);\n void attach(T object);\n void failure(String msg);\n}", "public void notifyChangementJoueurs();", "public void notifyObservers(int UPDATE_VALUE){\n\t\tfor(int i = 0; i < observerNodes.size();i++){\n\t\t\tNode currentNode = observerNodes.get(i);\n\t\t\tif(currentNode.filterType.filter(UPDATE_VALUE)) {\n\t\t\t\t\tcurrentNode.listen(UPDATE_VALUE);\n\t\t }\n\t\t}\n\t}", "public Conservable[] getListener() throws SQLException{\n return listener;\n }", "public interface OnDataChangedListener<T> {\n\tvoid onDataChanged(List<T> list);\n}", "void enableObserver() {\n dataSourcesPanel.addObserver(this);\n }", "@Override\n\tpublic void saveNotifications() {\n\t}", "protected void notifyRead(){\n indexList.clear();\n int rows = bank.getRows();\n for(int i = 0; i < rows; i++){\n int value = bank.getInt(filterVar, i);\n if (filterList.contains(value)) indexList.add(i);\n }\n }", "public List<DatastreamVersion> listChangedDatastreams();", "static void NotifyCorrespondingObservers() {}", "protected void notifyChangeListeners() { \n Utilities.invokeLater(new Runnable() {\n public void run() { for(ChangeListener l: _changeListeners) l.apply(this); }\n });\n }", "public interface DataCallback {\n public void onData(List t);\n}", "public interface DataSourceNotifyController<Adapter, DataSource> extends DataSourceController<DataSource> {\n\n\tDataSourceNotifyController<Adapter, DataSource> notifyDataSetChanged();\n\n\t@NonNull\n\tAdapter getDataSourceAdapter();\n}", "@Override\n public void notifySubscribers(Bundle notification) {\n for (ISubscriber subscriber : subscribers) {\n List<SubscriberFilter> filters = subscriber.getFilters();\n\n if (notification.getString(\"notificationType\").equals(subscriber.getNotificationType())) {\n if (notification.getString(\"userId\").equals(subscriber.getUser().getAuthUserID())) {\n if (!filters.isEmpty()) {\n List<Boolean> filterResults = new ArrayList<>();\n\n Object entity = notification.getSerializable(\"entity\");\n HashMap entityHashMap = (HashMap)entity;\n\n for (int index = 0; index < filters.size(); index++) {\n Object entityValue = entityHashMap.get(filters.get(index).getField());\n\n if (entityValue != null) {\n filterResults.add(filters.get(index).getValues().contains(entityValue));\n }\n }\n\n if (!filterResults.contains(false)) {\n entityHashMap.put(\"notificationId\", notification.getString(\"notificationId\"));\n entityHashMap.put(\"userId\", notification.getString(\"userId\"));\n subscriber.update(notification);\n }\n } else {\n subscriber.update(notification);\n }\n }\n }\n }\n }", "public void fireListenersOnPaths(Collection<IPath> pathList) {\r\n\t\tfor (Pair<IPath, IResourceChangeHandler> entry : trackedResources) {\r\n\t\t\tif (pathList.contains(entry.first)) {\r\n\t\t\t\tentry.second.resourceChanged(entry.first);\r\n\t\t\t}\r\n\t\t}\t\t\r\n\t}", "private void notifyObjectAdded(int index0, int index1) {\n\t\tlisteners.forEach(l -> l.objectsAdded(this, index0, index1));\n\t}", "void write(List<Object> values) throws TransportException;", "public interface INetworkNotifier {\n public void dataResult(List<Parc> parcs);\n}", "public void addListDataToDB() {\n\n for (int i = 1; i < 10; i++) {\n TimerDisplay timer = new TimerDisplay();\n timer.setCurrentDate(\"Jan 0\" + i + \" 2017 00:00\");\n timer.setEndDate(\"Jan 0\" + (i + 2) + \" 2017 00:00\");\n timer.setPercentage();\n\n databaseHelper.addDate(timer);\n //listTimers.add(timer);\n }\n }", "@Override\n\tpublic void addNotify() {\n\t\tsuper.addNotify();\n\t\t// Buffer\n\t\tcreateBufferStrategy(2);\n\t\ts = getBufferStrategy();\n\t}", "@Override\n public void writeToDb(List<String> data) {\n\n try {\n openConnection();\n if (validateData((ArrayList<String>) data)) {\n for (String datum : data) {\n bufferedWriter.write(getDate() + \" - \" + datum);\n bufferedWriter.newLine();\n }\n bufferedWriter.write(\"==================\\n\");\n System.out.println(\"All data is written to MS SQL DB\");\n closeConnection();\n }\n } catch (IOException e) {\n System.err.println(\"ERROR!!!\");\n e.printStackTrace();\n }\n\n }", "private void saveObserverUpdate(String value) {\n conversionResults += value + \"\\n\";\n }", "protected void fireConfigUpdated()\r\n {\r\n List executeListeners = new ArrayList(listeners);\r\n \r\n for (int i=0; i < executeListeners.size(); i++)\r\n {\r\n IConfigurationListener listener = (IConfigurationListener) executeListeners.get(i);\r\n listener.configUpdated();\r\n }\r\n }", "private void notifyComboBoxModelChange(int index0, int index1)\n {\n for(ListDataListener l : comboBoxModelListDataListeners)\n l.contentsChanged(new ListDataEvent(this, ListDataEvent.CONTENTS_CHANGED, index0, index1));\n }", "protected void AddEvents()\r\n {\r\n INotifyPropertyChanged propParent = (INotifyPropertyChanged)getProxyParent();\r\n propParent.getPropertyChanged().addObservers(filterPropertyChanges);\r\n }", "public interface DataWriter extends DataAdapter {\n\n /**\n * add an item to the list of pending work to be written.\n *\n * @param record DataRecord to add\n */\n void addItem(DataRecord record);\n\n /**\n * flush the list of work to be written\n */\n void flushBatch();\n\n /**\n * called by the system just prior to a normal shutdown.\n */\n void finish();\n\n\n}", "@SuppressWarnings(\"unchecked\")\n \tprivate void notifyPrepared() {\n \t\tfor (final L next : getListeners()) {\n \t\t\tnext.prepared((S) this);\n \t\t}\n \t\tfor (final ISimpleNavigationNodeListener next : getSimpleListeners()) {\n \t\t\tnext.prepared(this);\n \t\t}\n \n \t}", "public void buildData() {\n try {\n userIDObservableList.addAll(workerAdaptor.getWorkerList());\n } catch (SQLException ex) {\n System.out.println(ex.getMessage());\n }\n }", "public List<String> getDataChangeTaskIdsToObserve() {\n return null;\n }", "public interface OnDeliveriesUpdatedListener {\n void onDeliveriesUpdated(List<Delivery> deliveries);\n}", "@Override\n void notifys() {\n for (Observer o : observers) {\n o.update();\n }\n }", "void notifyAdapters(Object event);", "@Override\n\tpublic void notifyObserver() {\n\t\tEnumeration<ObserverListener> enumd = vector.elements();\n\t\twhile (enumd.hasMoreElements()) {\n\t\t\tObserverListener observerListener = enumd\n\t\t\t\t\t.nextElement();\n\t\t\tobserverListener.observer();\n\t\t\tobserverListener.obsupdata();\n\t\t}\n\t}", "@Test\r\n public void testAPIChange() {\r\n WithListValue<String> p = new WithListValue<>();\r\n Property<ObservableList<String>> property = p.itemsProperty();\r\n ChangeListener<? super ObservableList<String>> listener = new ChangeListener<ObservableList<String>>() {\r\n\r\n @Override\r\n public void changed(\r\n ObservableValue<? extends ObservableList<String>> observable,\r\n ObservableList<String> oldValue,\r\n ObservableList<String> newValue) {\r\n LOG.info(\"dummy dooo!\");\r\n \r\n }\r\n } ;\r\n \r\n property.addListener(listener);\r\n// ListProperty items = table.itemsProperty();\r\n }", "private void sendInfo() {\n Log.v(TAG, \"sendInfo() contentListSize \"+this.contentList.size()+\" interestListSize \"+this.interestList.size());\n\n D2DAddContentNotificationEvent addContentEvent = new D2DAddContentNotificationEvent(false);\n addContentEvent.contentList = this.contentList;\n this.sendEvent(addContentEvent);\n\n D2DAddInterestNotificationEvent addInterestEvent = new D2DAddInterestNotificationEvent(false);\n addInterestEvent.interestList = this.interestList;\n this.sendEvent(addInterestEvent);\n }", "protected void giveValueToListeners(String value, MinMaxEvent evt) {\n for(int i = 0; i < listeners.size(); i++) {\n listeners.get(i).setValueOfNode(value, evt);\n }\n }", "@Override\r\n\tpublic void OnMicQueueNotify(List<stMicInfo> micinfolists) {\n\t\t\r\n\t\tString tempIDS[] = new String[micinfolists.size()];\r\n\t\tString uniqueIDS[] = new String[micinfolists.size()];\r\n\t\r\n\t\tint j = 0;\r\n\t\tfor (Iterator<stMicInfo> i = micinfolists.iterator(); i.hasNext();)\r\n\t\t{ \r\n\t\t\tstMicInfo userinfoRef = i.next(); \r\n\t\t\ttempIDS[j] = String.valueOf(userinfoRef.getTempid());\r\n\t\t\tuniqueIDS[j] = userinfoRef.getUniqueid();\r\n\t\t\tj++;\r\n\t\t} \r\n\t\tMicQueueResult(tempIDS,uniqueIDS);\r\n\t}", "public Collection<String> getNotifyList() {\n Set<String> result;\n String list = getDbProperties().getProperty(Constants.NOTIFY_LIST);\n if (list != null) {\n result = Arrays.stream(list.split(\"[, ]+\"))\n .map(String::trim)\n .collect(Collectors.toSet());\n } else {\n result = new HashSet<>();\n }\n return result;\n }", "public abstract Set<WritableSession> getSubscribers(F filter);", "@Override\n\tpublic void saveDataSource() {\n\t\tsaveServerOffline();\n\t}", "public synchronized void write() {\n while (events.size() == size) {\n try {\n wait();\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n }\n events.add(new Date());\n System.out.printf(\"Write :%d\\n\", events.size());\n notifyAll();\n }", "protected void updateAll() {\n for (String key : listenerMap.keySet()) {\n updateValueForKey(key, true);\n }\n }", "public void storeNotificationsToNotificationList(String notificationDetails)\n {\n String[] allNoti = notificationDetails.split(\";\");\n \n \n for (int line = 0; line < allNoti.length ; line++)\n {\n String[] details = allNoti[line].split(\"///\");\n String jobSeekerUsername = details[0];\n String[] notifications = details[1].split(\",\");\n ArrayList<String> notification = new ArrayList<String>();\n for (int i = 0; i < notifications.length; i++)\n {\n notification.add(notifications[i]);\n }\n getJobSeeker(jobSeekerUsername).setNotification(notification);\n }\n }", "@Override\n\tpublic void Notify() {\n\t\tfor (Observer observer : obs) {\n\t\t\tobserver.update();\n\t\t}\n\t}", "public void dataChanged() {\n\t\tif (wijzigInfo)\n\t\t\twijzigInfo();\n\n\t\tsetChanged();\n\t\tnotifyObservers(\"dataChanged\");\n\t}", "private static void fireAddedEvent(ProtocolDescriptor pd) {\n\t\tfor (ProtocolStoreListener l : storeListener)\n\t\t\tl.protocolAdded(pd);\n\t}", "void onDataChanged();", "@Override\n public void DataIsInserted() {\n }", "void saveNotifyDataToTable(HashSet<String> data)\n\t\t{\n\t\t\tsaveFIXDataSet(data);\n\t\t\t/*Iterator<String> itr=data.iterator();\n\t\t\twhile (itr.hasNext())\n\t\t\t{\n\t\t\t\tString fixLine=itr.next();\n\t\t\t\tint ix9=fixLine.indexOf(\"|120=\");\n\t\t\t\tif (ix9 < 0) ix9=fixLine.length()-1;\n\t\t\t\t\n\t\t\t\t//aAg.saveFIXData(fixLine.substring(0, ix9+1), this);\n\t\t\t}*/\n\t\t\t\n\t\t\treturn;\n\t\t}", "public void notifyObservers() {\n for (int i = 0; i < observers.size(); i++) {\n Observer observer = (Observer)observers.get(i);\n observer.update(this.durum);\n }\n }", "private void updateConnectionsList() {\n ConnectionsWrapper connections = new ConnectionsWrapper();\n connections.setConnectionList(new ArrayList<>(connectionMap.values()));\n XMLFileManager.saveXML(\"connections.xml\", connections, ConnectionsWrapper.class);\n }", "private void notifyListeners(ProteusOpaqueData pod) {\n \tEnumeration<ProteusOpaqueListener> e = listeners.elements();\n \twhile (e.hasMoreElements()) {\n \t\te.nextElement().newOpaqueData(pod);\n \t}\n }", "@Override\n @SuppressWarnings(\"unchecked\")\n protected void customSync() {\n Exchanger<Void>[] exchangers = (Exchanger<Void>[]) new Exchanger<?>[PRODUCERS_COUNT];\n\n for (int i = 0; i < PRODUCERS_COUNT; i++) {\n exchangers[i] = new Exchanger<>();\n new Producer(params.dataResults, params.postResult, exchangers[i]).start();\n }\n\n new Consumer(params.postFinish, exchangers).start();\n }", "public void addObservers(List<RegisterObserver> observers){\r\n registerObservers.addAll(observers);\r\n }", "public void onDataChanged();", "private static void informListeners() {\r\n\t\tfor (ATEListener l : listeners) {\r\n\t\t\tl.classListChanged( );\r\n\t\t}\r\n\t}", "private EventNotifier<OIFitsCollectionManagerEvent, OIFitsCollectionManagerEventType, Object> getPlotListChangedEventNotifier() {\n return this.oiFitsCollectionManagerEventNotifierMap.get(OIFitsCollectionManagerEventType.PLOT_LIST_CHANGED);\n }", "protected void fireContentsChanged() {\r\n\t// Guaranteed to return a non-null array\r\n\tObject[] listeners = listenerList.getListenerList();\r\n\tListDataEvent e = null;\r\n\t// Process the listeners last to first, notifying\r\n\t// those that are interested in this event\r\n\tfor (int i = listeners.length-2; i>=0; i-=2) {\r\n\t if (listeners[i]==ListDataListener.class) {\r\n\t\t// Lazily create the event:\r\n\t\tif (e == null) {\r\n\t\t e = new ListDataEvent(this, ListDataEvent.CONTENTS_CHANGED,\r\n\t\t\t\t\t 0, getSize()-1);\r\n\t\t}\r\n\t\t((ListDataListener)listeners[i+1]).contentsChanged(e);\r\n\t }\r\n\t}\r\n }", "@Test\r\n public void testListPropertyAdapterSetListOnObjectProperty() {\r\n ObservableList<String> list = createObservableList(true);\r\n ObjectProperty<ObservableList<String>> objectProperty = new SimpleObjectProperty<>(list);\r\n ListProperty<String> listProperty = listProperty(objectProperty);\r\n ObservableList<String> otherList = createObservableList(true);\r\n otherList.remove(0);\r\n ChangeReport objectReport = new ChangeReport(objectProperty);\r\n ChangeReport report = new ChangeReport(listProperty);\r\n objectProperty.set(otherList);\r\n assertEquals(\"sanity: change event from objectProperty\", 1, objectReport.getEventCount());\r\n assertEquals(\"must fire change on setting list to objectProperty\", 1, report.getEventCount());\r\n }", "@Test @Ignore\r\n public void testListPropertyNotificationDetails() {\r\n ObservableList<String> list = createObservableList(true);\r\n ListProperty<String> lp = new SimpleListProperty<>(list);\r\n ListChangeListener l = c -> FXUtils.prettyPrint(c);\r\n LOG.info(\"change from listProperty: modifying list\");\r\n lp.addListener(l);\r\n LOG.info(\"set same element\");\r\n list.set(0, list.get(0));\r\n LOG.info(\"set same list\");\r\n list.setAll(createObservableList(true));\r\n // fires one event with two changes\r\n LOG.info(\"remove two not subsequent\");\r\n list.removeAll(list.get(1), list.get(5)); \r\n LOG.info(\"retain all with complete list\");\r\n // fires nothing \r\n list.retainAll(createObservableList(true));\r\n LOG.info(\"setAll to initial\");\r\n list.setAll(createObservableList(true));\r\n // fires one event with 3 changes of type remove\r\n list.retainAll(list.get(0), list.get(3), list.get(7));\r\n LOG.info(\"setall with new list\");\r\n list.setAll(\"one\", \"twoorwhat\");\r\n // fires one replaced event for each element \r\n UnaryOperator<String> op = p -> {\r\n if (p.length() > 3) return p;\r\n return p + 3;\r\n }; \r\n list.replaceAll(op); \r\n // fires setAll\r\n FXCollections.replaceAll(list, \"one\", \"other\");\r\n list.removeAll(\"one\", \"two\");\r\n LOG.info(\"reset ListProperty to initial list\");\r\n lp.set(createObservableList(true));\r\n }", "public void notifyConfigChange() {\n }", "List<Runnable> getItemListeners();", "private void notifyListenersSkyModelUpdate(SkyModelUpdate status) {\n\t\tif (!deleteListeners.isEmpty()) {\n\t\t\tfor (int id = 0; id < deleteListeners.size(); id++) {\n\t\t\t\tSkyModelUpdateListener l = deleteListeners.get(id);\n\t\t\t\tif (listeners.contains(l)) {\n\t\t\t\t\tlisteners.remove(l);\n\t\t\t\t\tslogger.create().info().level(2).msg(\"Removing listener \" + l).send();\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\t// add new listeners\n\t\tif (!addListeners.isEmpty()) {\n\t\t\tfor (int ia = 0; ia < addListeners.size(); ia++) {\n\t\t\t\tSkyModelUpdateListener l = addListeners.get(ia);\n\t\t\t\tif (!listeners.contains(l)) {\n\t\t\t\t\tlisteners.add(l);\n\t\t\t\t\tslogger.create().info().level(2).msg(\"Adding new listener \" + l).send();\n\t\t\t\t}\n\t\t\t}\n\n\t\t}\n\n\t\t// broadcast\n\t\tfor (int il = 0; il < listeners.size(); il++) {\n\t\t\tSkyModelUpdateListener l = null;\n\t\t\ttry {\n\t\t\t\tl = listeners.get(il);\n\t\t\t\tif (status instanceof SkyModelSeeingUpdate) {\n\t\t\t\t\tSkyModelSeeingUpdate seeing = (SkyModelSeeingUpdate) status;\n\t\t\t\t\tl.seeingUpdated(seeing.getStatusTimeStamp(), seeing.getRawSeeing(), seeing.getCorrectedSeeing(),\n\t\t\t\t\t\t\tseeing.getPredictedSeeing(), seeing.getElevation(), seeing.getAzimuth(),\n\t\t\t\t\t\t\tseeing.getWavelength(), seeing.isStandard(), seeing.getSource(), seeing.getTargetName());\n\t\t\t\t} else if (status instanceof SkyModelExtinctionUpdate) {\n\t\t\t\t\tSkyModelExtinctionUpdate photom = (SkyModelExtinctionUpdate) status;\n\t\t\t\t\tl.extinctionUpdated(photom.getStatusTimeStamp(), photom.getExtinction());\n\t\t\t\t}\n\n\t\t\t} catch (Exception e) {\n\t\t\t\tif (l != null) {\n\t\t\t\t\tdeleteListeners.add(l);\n\t\t\t\t\tslogger.create().info().level(2).msg(\"Adding unresponsive listener: \" + l + \" to kill list\").send();\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t}", "private void writeSensorData(ArrayList<Integer> list, String name) {\n printWriter.println(\"<gx:SimpleArrayData name=\\\"\" + name + \"\\\">\");\n for (int i = 0; i < list.size(); i++) {\n printWriter.println(\"<gx:value>\" + list.get(i) + \"</gx:value>\");\n }\n printWriter.println(\"</gx:SimpleArrayData>\");\n }" ]
[ "0.59480494", "0.5774183", "0.5762268", "0.55825603", "0.54431975", "0.53748906", "0.5370607", "0.53639835", "0.53610134", "0.5336075", "0.5315234", "0.52948976", "0.5281514", "0.52772427", "0.52691287", "0.52630246", "0.5252129", "0.52265507", "0.5224693", "0.5203706", "0.5202157", "0.5176816", "0.51475495", "0.514201", "0.5140591", "0.5130273", "0.5121536", "0.5118862", "0.51092565", "0.5109031", "0.5106035", "0.5103476", "0.5103476", "0.5103476", "0.5099115", "0.5099115", "0.50953263", "0.5092634", "0.50819314", "0.5079081", "0.50608057", "0.50598127", "0.5040825", "0.5015456", "0.49946368", "0.49673796", "0.49613327", "0.4956395", "0.49506423", "0.49472278", "0.49457526", "0.493814", "0.49374852", "0.49362394", "0.4915328", "0.49139616", "0.4906082", "0.48973846", "0.4896124", "0.48826918", "0.48800853", "0.4874804", "0.48729974", "0.4871285", "0.4869432", "0.48647025", "0.48518735", "0.48425788", "0.48395357", "0.48352087", "0.4825571", "0.48216954", "0.4821039", "0.4817835", "0.48163956", "0.4816268", "0.48078287", "0.47985435", "0.4798498", "0.47946978", "0.47900274", "0.4786389", "0.47757545", "0.47732043", "0.4758066", "0.47564983", "0.47562432", "0.47538823", "0.47530517", "0.4753046", "0.47528842", "0.47518355", "0.4751766", "0.475138", "0.47502798", "0.4749174", "0.47469416", "0.47448564", "0.4742996", "0.47399253", "0.47397506" ]
0.0
-1
DeepCopy Many of the data sources shown above make what is called a shallow copy of the data source around which they are wrapped. A TrimmedDataSource does not make a copy of the list it wraps but rather passes data input and output calls to it. Sometimes you might want to make a full copy of the data underlying any and all data sources you've chained together. For instance to calculate a Median of a data set you need to make a DeepCopy of the original data so you can sort it without affecting any of the underlying data sets. A DeepCopy returns a set of data with all data values copied to newly allocated memory (or disk storage as appropriate).
@SuppressWarnings("unused") void example17() { // make a list of 10,000 numbers IndexedDataSource<Float32Member> original = nom.bdezonia.zorbage.storage.Storage.allocate(G.FLT.construct(), 10000); // make a list that is a subset of the previous list (numbers from locations 1,000 - 2,999) IndexedDataSource<Float32Member> trimmed = new TrimmedDataSource<>(original, 1000, 2000); // then create a new memory copy of those 2000 numbers IndexedDataSource<Float32Member> theCopy = DeepCopy.compute(G.FLT, trimmed); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "DataSource clone();", "@SuppressWarnings(\"unused\")\n\tvoid example15() {\n\n\t\t// make a list of 10,000 numbers\n\t\t\n\t\tIndexedDataSource<Float32Member> original =\n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.FLT.construct(), 10000);\n\n\t\t// make a list that is a subset of the previous list (numbers from locations 1,000 - 2,999)\n\t\t\n\t\tIndexedDataSource<Float32Member> trimmed = new TrimmedDataSource<>(original, 1000, 2000);\n\t\t\n\t\t// the trimmed list has length 2,000 and is indexed from 0 to 1,999 returning data from\n\t\t// locations 1,000 - 2,999 in the original list.\n\t\t\n\t}", "protected AbstractChartModel copy(AbstractChartModel aCopy) {\n aCopy.title = title;\n aCopy.xAxisTitle = xAxisTitle;\n aCopy.yAxisTitle = yAxisTitle;\n aCopy.xRangeMax = xRangeMax;\n aCopy.xRangeMin = xRangeMin;\n aCopy.xRangeIncr = xRangeIncr;\n aCopy.yRangeMax = yRangeMax;\n aCopy.yRangeMin = yRangeMin;\n aCopy.yRangeIncr = yRangeIncr;\n aCopy.simModel = simModel;\n ArrayList list = new ArrayList();\n for (int i = 0, n = dataSources.size(); i < n; i++) {\n GuiChartDataSource ds = (GuiChartDataSource) dataSources.get(i);\n list.add(ds.copy());\n }\n aCopy.dataSources = list;\n\n return aCopy;\n }", "public ConfabulatorObject getCopy() {\n\t\tConfabulatorObject copy = new ConfabulatorObject(getMessenger());\n\t\tlockMe(this);\n\t\tint maxD = maxLinkDistance;\n\t\tint maxC = maxLinkCount;\n\t\tList<Link> linksCopy = new ArrayList<Link>();\n\t\tfor (Link lnk: links) {\n\t\t\tlinksCopy.add(lnk.getCopy());\n\t\t}\n\t\tunlockMe(this);\n\t\tcopy.initialize(maxD,maxC,linksCopy);\n\t\treturn copy;\n\t}", "public void copy(DataRequest original){\n\t\t//potential problems with object sharing\n\t\tfilters = \toriginal.get_filters();\n\t\tsort_by = \toriginal.get_sort_by();\n\t\tcount = \toriginal.get_count();\n\t\tstart = \toriginal.get_start();\n\t\tsource = \toriginal.get_source();\n\t\tfieldset =\toriginal.get_fieldset();\n\t\trelation = \toriginal.get_relation();\n\t}", "public void makeDataSourceCloneable(){\n\t\tsetMainDataSource(Manager.createCloneableDataSource(getMainDataSource()));\n\t\t/*\n\t\tif(processor==null || processor.getDataOutput()==null){\n\t\t\tsetMainDataSource(Manager.createCloneableDataSource(getMainDataSource()));\n\t\t}else{\n\t\t\tsetMainDataSource(Manager.createCloneableDataSource(processor.getDataOutput()));\n\t\t}\n\t\t*/\n\t}", "public ProcessedDynamicData deepCopy( ) {\r\n\r\n ProcessedDynamicData copy = new ProcessedDynamicData( this.channelId );\r\n\r\n copy.channelId = this.channelId;\r\n copy.dateTimeStamp = new java.util.Date( this.dateTimeStamp.getTime() );\r\n copy.samplingRate = this.samplingRate;\r\n copy.eu = this.eu;\r\n\r\n copy.min = this.min;\r\n copy.max = this.max;\r\n\r\n copy.measurementType = this.measurementType;\r\n copy.measurementUnit = this.measurementUnit;\r\n\r\n // data and labels\r\n List<Double> dataCopy = new Vector<Double>();\r\n for( int i = 0; i < this.data.size(); i++ ) {\r\n dataCopy.add( new Double( this.data.get( i ) ) );\r\n }\r\n copy.setData( dataCopy );\r\n\r\n List<Double> dataLabels = new Vector<Double>();\r\n for( int i = 0; i < this.dataLabels.size(); i++ ) {\r\n dataLabels.add( new Double( this.dataLabels.get( i ) ) );\r\n }\r\n copy.setDataLabels( dataLabels );\r\n\r\n // create a deep copy of overalls\r\n if( overalls != null ) {\r\n copy.overalls = new OverallLevels( this.overalls.getChannelId() );\r\n copy.overalls.setDateTimeStampMillis( this.getDateTimeStampMillis() );\r\n Vector<String> overallKeys = this.overalls.getKeys();\r\n for( int i = 0; i < overallKeys.size(); i++ ) {\r\n copy.overalls.addOverall( new String( overallKeys.elementAt( i ) ),\r\n new Double( this.overalls.getOverall( overallKeys.elementAt( i ) ) ) );\r\n }\r\n }\r\n\r\n copy.xEUnit = this.xEUnit;\r\n copy.yEUnit = this.yEUnit;\r\n\r\n copy.xSymbol = this.xSymbol;\r\n copy.ySymbol = this.ySymbol;\r\n copy.xPhysDomain = this.xPhysDomain;\r\n copy.yPhysDomain = this.yPhysDomain;\r\n \r\n copy.noOfAppendedZeros = this.noOfAppendedZeros;\r\n\r\n return copy;\r\n }", "DataContext copy();", "public List<T> getCopyOfUnfilteredItemList(){\n synchronized (listsLock){\n if (originalList != null){\n return new ArrayList<T>(originalList);\n } else {\n // if original list is null filtered list is unfiltered\n return new ArrayList<T>(filteredList);\n }\n }\n }", "@Override\n public RawStore copy() {\n return new RawStore(this.toRawCopy2D(), myNumberOfColumns);\n }", "private Object[] deepCopy()\n {\n Object[] newList = new Object[size];\n\n int newListPosition = 0;\n for (int i =0; i < size; i++)\n {\n if (list[i] != null)\n {\n newList[newListPosition++] = list[i];\n }\n }\n\n return newList;\n }", "@Override\n\tpublic SecuredRDFList copy();", "Prototype makeCopy();", "public void mirror(Dataset other) {\n clear();\n this.ntree.addAll(other.ntree);\n }", "private static <T> void cloneCollection(Collection<T> originalCollection, Collection<T> clonedCollection, PropertyFilter propertyFilter) {\n\t\tJpaCloner jpaCloner = new JpaCloner(propertyFilter);\n\t\tSet<Object> exploredEntities = new HashSet<Object>();\n\t\tfor (T root : originalCollection) {\n\t\t\tclonedCollection.add(clone(root, jpaCloner, exploredEntities));\n\t\t}\n\t}", "public MultiList<R,S> copy(){\n MultiList<R,S> retVal = new MultiList<R,S>();\n retVal.putAll_forCopy(this);\n return retVal;\n }", "@Override\n public weighted_graph copy() {\n weighted_graph copy = new WGraph_DS(this.ga);//create the copy graph via copy constructor\n return copy;\n }", "@Test\n\tpublic void testCopy2() {\n\n\t\tint[] arr = { 1, 2, 3, 7, 8 }; // this list\n\t\tSLLSet listObj2 = new SLLSet(arr);\n\t\tSLLSet copied = listObj2.copy();\n\t\tcopied.add(-1);\n\t\tString expectedObj2 = \"1, 2, 3, 7, 8\";\n\t\tString expectedCopied = \"-1, 1, 2, 3, 7, 8\";\n\t\tint expectedObj2Size = 5;\n\t\tint expectedCopiedSize = 6;\n\n\t\tassertEquals(expectedObj2Size, listObj2.getSize());\n\t\tassertEquals(expectedObj2, listObj2.toString());\n\n\t\tassertEquals(expectedCopiedSize, copied.getSize());\n\t\tassertEquals(expectedCopied, copied.toString());\n\n\t}", "public static DeviceMeasurementsSearchResults copy(SearchResults<IDeviceMeasurements> source)\r\n\t throws SiteWhereException {\r\n\tDeviceMeasurementsSearchResults result = new DeviceMeasurementsSearchResults();\r\n\tList<DeviceMeasurements> converted = new ArrayList<DeviceMeasurements>();\r\n\tfor (IDeviceMeasurements measurement : source.getResults()) {\r\n\t converted.add(DeviceMeasurements.copy(measurement));\r\n\t}\r\n\tresult.setNumResults(source.getNumResults());\r\n\tresult.setResults(converted);\r\n\treturn result;\r\n }", "@Override\r\n public NumericObjectArrayList makeDeepCopy() {\r\n NumericObjectArrayList list = new NumericObjectArrayList();\r\n for (int i = 0; i < this.getCount(); i++) {\r\n try {\r\n list.insert(i, this.getValueAt(i));\r\n } catch (IndexRangeException ex) {\r\n //Shouldn't happen\r\n }\r\n }\r\n return list;\r\n }", "Nda<V> shallowCopy();", "protected Factorization copy(){\n Factorization newFactor = new Factorization(this.mdc);\n //shallow copy\n newFactor.setRecipes(recipes);\n newFactor.setIngredients(ingredients);\n newFactor.setUserMap(userMap);\n newFactor.setUserMapReversed(userMap_r);\n newFactor.setRecipeMap(recipeMap);\n newFactor.setRecipeMapReversed(recipeMap_r);\n newFactor.setIngredientMap(ingredientMap);\n newFactor.setIngredientMapReversed(ingredientMap_r);\n \n //deep copy\n List<User> userCopy = new ArrayList<User>();\n for(User curr: this.users){\n userCopy.add(new User(curr.getId()));\n }\n newFactor.setUsers(userCopy);\n newFactor.setDataset(dataset.copy());\n newFactor.updateInitialSpace();\n return newFactor;\n }", "Model copy();", "public Data copy(Object value) {\n if (mValue instanceof Data) {\n ((Data) mValue).copy(value);\n } else {\n mValue = value;\n }\n return this;\n }", "@Override\n\tprotected void copy(Object source, Object dest) {\n\t\t\n\t}", "public Query copy() {\r\n\tQuery queryCopy = new Query();\r\n\tqueryCopy.terms = (LinkedList<String>) terms.clone();\r\n\tqueryCopy.weights = (LinkedList<Double>) weights.clone();\r\n\treturn queryCopy;\r\n }", "public void copy() {\n\n\t}", "public SetSet deepCopy(){\n\t\tSetSet copy = new SetSet();\n\t\tfor(int i=0;i<size();i++){\n\t\t\tcopy.add(get(i).deepCopy());\n\t\t}\n\t\treturn copy;\n\t}", "@Override\n\tpublic graph copy() {\n\t\tgraph copy = new DGraph();\n\t\tCollection<node_data> nColl = this.GA.getV();\n\t\tfor (node_data node : nColl) {\n\t\t\tnode_data temp = new Node((Node) node );\n\t\t\tcopy.addNode(node);\n\t\t}\n\t\tCollection<node_data> nColl2 = this.GA.getV();\n\t\tfor (node_data node1 : nColl2) {\n\t\t\tCollection<edge_data> eColl = this.GA.getE(node1.getKey());\n\t\t\tif (eColl!=null) {\n\t\t\t\tfor (edge_data edge : eColl) {\n\t\t\t\t\tcopy.connect(edge.getSrc(), edge.getDest(), edge.getWeight());\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn copy;\n\t}", "private Instances deepCopy(Instances data) {\n Instances newInst = new Instances(data);\n\n newInst.clear();\n\n for (int i = 0; i < data.size(); i++) {\n Instance ni = new DenseInstance(data.numAttributes());\n for (int j = 0; j < data.numAttributes(); j++) {\n ni.setValue(newInst.attribute(j), data.instance(i).value(data.attribute(j)));\n }\n newInst.add(ni);\n }\n\n return newInst;\n }", "@Override\n public Collection<SimpleModel> mungee(Collection<MockData> src) {\n return src\n .stream()\n .filter(data -> data.getContent() != null)\n .map(SimpleModel::build)\n .collect(Collectors.toList());\n }", "public Weights getCopy() {\n\t\tdouble[] wnew = new double[w.length];\n\t\t\n\t\tboolean didAverage = false;\n\t\tif (!averaged) {\n\t\t\taverage();\n\t\t\tdidAverage = true;\n\t\t}\n\t\t\n\t\tfor (int i = 0; i < w.length; i++)\n\t\t\twnew[i] = w[i]*scale;\n\t\t\n\t\tif (didAverage)\n\t\t\tunaverage();\n\t\t\n\t\treturn new Weights(wnew);\n\t}", "public T[] getClonedTrimmed(T[] ar) {\r\n for (int i = offset; i < offset + count; i++) {\r\n @SuppressWarnings(\"unchecked\")\r\n T v = (T)objects[i];\r\n ar[i] = v;\r\n }\r\n return ar;\r\n }", "public Object cloner() {\n return cloner((Sommet)origine.cloner(), (Sommet)destination.cloner());\n }", "public Object clone() throws CloneNotSupportedException {\n/* 354 */ SlidingCategoryDataset clone = (SlidingCategoryDataset)super.clone();\n/* 355 */ if (this.underlying instanceof PublicCloneable) {\n/* 356 */ PublicCloneable pc = (PublicCloneable)this.underlying;\n/* 357 */ clone.underlying = (CategoryDataset)pc.clone();\n/* */ } \n/* 359 */ return clone;\n/* */ }", "public void copyDataFrom(ParamUnit other)\r\n\t{\r\n\t\tif (this.data.row != other.data.row || this.data.col != other.data.col)\r\n\t\t\tthrow new DeepException(\"Cannot copy data from a different dimension.\");\r\n\t\tthis.data.copyFrom(other.data);\r\n\t}", "public Results copy()\n {\n Results copy = new Results();\n for(Object object : results) {\n copy.add( object );\n }\n return copy;\n }", "public MedianDatasource() {\n super(generateStacks(calculateStackCount(5, 100, 200), 15, 30,\n new double[]{50, 40, 35, 30, 20, 10, 7, 5, 2}, 3));\n }", "public Matrix copy() {\n Matrix X = new Matrix(m,n);\n double[][] C = X.getArray();\n for (int i = 0; i < m; i++) {\n for (int j = 0; j < n; j++) {\n C[i][j] = data[i][j];\n }\n }\n return X;\n }", "ArrayList deepCopyShapeList(List aShapeList){\n ArrayList newList = new ArrayList();\r\n\r\n if (aShapeList.size() > 0) {\r\n Iterator iter = aShapeList.iterator();\r\n\r\n while (iter.hasNext())\r\n newList.add(((TShape)iter.next()).copy());\r\n }\r\n return\r\n newList;\r\n}", "private static void copy(List<? super Number> dest, List<? extends Number> src) {\n for (int i = 0; i < src.size(); i++) {\n dest.set(i, src.get(i));\n //dest.add(src.get(i));\n }\n }", "public static void copy(java.util.List arg0, java.util.List arg1)\n { return; }", "public DataTrack cloneWithNewSources(ArrayList<DataSource> newsources) {\n DataTrack copy=new DataTrack(this.name, this.datatype, this.sourceSite, this.description); \n copy.directivesProtocol=this.directivesProtocol;\n for (DataSource source:newsources) {\n source.dataTrack=copy;\n copy.datasources.add(source);\n }\n return copy; \n }", "@Override\r\n public weighted_graph copy() {\n weighted_graph copy = new WGraph_DS();\r\n for (node_info curr : this.Graph.getV()) { //The loop passes through all the ver' of the graph\r\n Nodes t = new Nodes(curr); //create new node\r\n copy.addNode(t.key); //copy the the old node to the new node\r\n }\r\n for (node_info curr0 : this.Graph.getV()) {\r\n for (node_info curr1 : this.Graph.getV(curr0.getKey())) { //this loops pass over the all nodes and copy the connection\r\n double i = this.Graph.getEdge(curr0.getKey(), curr1.getKey());\r\n if (i != -1) {\r\n copy.connect(curr0.getKey(), curr1.getKey(), i);\r\n }\r\n }\r\n }\r\n return copy;\r\n\r\n }", "public directed_weighted_graph deepCopy() {\n DWGraph_DS copyGraph = new DWGraph_DS(this); //create a new graph with the original graph data (only primitives)\n HashMap<Integer, node_data> copyNodesMap = new HashMap<>(); //create a new nodes HashMap for the new graph\n for (node_data node : nodes.values()) { //loop through all nodes in the original graph\n copyNodesMap.put(node.getKey(), new NodeData((NodeData) node)); //makes a duplicate of the original HashMap\n }\n copyGraph.nodes = copyNodesMap; //set the new graph nodes to the new HashMap we made.\n return copyGraph;\n }", "public CMObject copyOf();", "@Override\n public LocalStore<V> copy() {\n return this;\n }", "public List<Person> copyPersons() {\n\t\tList<Person> copyPersons = new ArrayList<Person>(personsOrig.size());\t// NOTE this is still an empty List with initial capacity of personsOrig size\r\n\t\t// unfortunately there isn't a clone or factory method in Collections. So have to create \"target\" collection with some garbage\r\n\t\tPerson p;\r\n\t\tfor (int i = 0; i < personsOrig.size(); i++) {\r\n\t\t\tp = new Person(\"\", 0);\r\n\t\t\tcopyPersons.add(p);\r\n\t\t}\r\n\t\tCollections.copy(copyPersons, personsOrig);\r\n\t\tSystem.out.println(\"persons copy:\" + copyPersons);\r\n\r\n\t\tCollections.sort(copyPersons);\r\n\t\tSystem.out.println(\"Sorted copy:\" + copyPersons);\r\n\r\n\t\tSystem.out.println(\"Original persons:\" + personsOrig);\r\n\t\treturn copyPersons;\r\n\t}", "public void removeIdenticalDataSources(DataSource source) {\n Iterator<DataSource> iter=datasources.iterator();\n while (iter.hasNext()) {\n DataSource s=iter.next();\n if (s.equals(source)) iter.remove();\n } \n }", "public SinglyLinkedList<E> copy() {\n SinglyLinkedList<E> copy = new SinglyLinkedList<>();\n for(Node<E> cur = head; cur != null; cur = cur.next) {\n copy.addLast(cur.item);\n }\n return copy;\n }", "public void copyData(TrianaType source) { // not needed\n }", "public static void restoreList() {\n\n if (copyList.isEmpty())\n return;\n\n\n getList().clear();\n\n for (Map<String, ?> item : copyList) {\n getList().add(item);\n }\n\n copyList.clear();\n //Log.d(\"test\", \"After restore: Champlist size \" + getSize() + \" copylist size \" + copyList.size());\n\n }", "@Override\n\tpublic CanvasItem copy() {\n\t\treturn null;\n\t}", "public CopyBuilder copy() {\n return new CopyBuilder(this);\n }", "IDataRow getCopy();", "public Object clone()\n {\n DataSetDivide new_op = new DataSetDivide( );\n // copy the data set associated\n // with this operator\n new_op.setDataSet( this.getDataSet() );\n new_op.CopyParametersFrom( this );\n\n return new_op;\n }", "public Complex makeDeepCopy() {\r\n Complex complex2 = new Complex(this.getReal(), this.getImaginary());\r\n return complex2;\r\n }", "public ModuleDescriptorAdapter copy() {\n ModuleDescriptorAdapter copy = new ModuleDescriptorAdapter(getId(), getDescriptor(), getComponentId());\n copyTo(copy);\n copy.metaDataOnly = metaDataOnly;\n return copy;\n }", "public static <T> List<T> clone(List<T> list, PropertyFilter propertyFilter) {\n\t\tList<T> clonedList = new ArrayList<T>(list.size());\n\t\tcloneCollection(list, clonedList, propertyFilter);\n\t\treturn clonedList;\n\t}", "Nda<V> deepCopy();", "protected Shingle copy() {\n return new Shingle(this);\n }", "public DoubleLinkedList clone() {\n\n\t\tDoubleLinkedList l = new DoubleLinkedList();\n\t\tDLNode n = head;\n\t\twhile (n != null) {\n\t\t\tif (n.val != Integer.MIN_VALUE) {\n\t\t\t\tl.pushBack(n.val);\n\t\t\t} else {\n\t\t\t\tl.pushBackRecursive(n.list.clone());\n\t\t\t}\n\t\t\tn = n.next;\n\t\t}\n\t\tl.elements = this.elements;\n\n\t\treturn l;\n\n\t}", "public MS2Scan clone(){\n\t\tMS2Scan result = cloneNoData();\n\t\tfor (int m=0; m<mzint.size(); m++){\n\t\t\tresult.addscan(mzint.get(m).getmz(), mzint.get(m).getint());\n\t\t}\n\t\treturn result;\n\t}", "default FlowEventDumpData deepCopy(FlowEventDumpData source) {\n FlowEventDumpData result = new FlowEventDumpDataImpl();\n copy(source, result);\n return result;\n }", "static void setCopying(){isCopying=true;}", "Component deepClone();", "public Record copy() {\n\t\treturn new Record(video, numOwned, numOut, numRentals);\n\t}", "public Object clone() {\r\n//STUB BEGIN\r\n \t/*\r\n DoubleLinkedList clone = null;\r\n try { \r\n \tclone = (DoubleLinkedList) super.clone();\r\n } catch (CloneNotSupportedException e) { \r\n \tthrow new InternalError();\r\n }*/ //JBSE still does not implement Object.clone\r\n \tDoubleLinkedList clone = new DoubleLinkedList();\r\n//STUB END\r\n\r\n // Put clone into \"virgin\" state\r\n//INSTRUMENTATION BEGIN\r\n //clone.header = new Entry(null, null, null);\r\n clone.header = new Entry(null, null, null, clone);\r\n//INSTRUMENTATION END\r\n clone.header.next = clone.header.previous = clone.header;\r\n clone.size = 0;\r\n clone.modCount = 0;\r\n\r\n // Initialize clone with our elements\r\n for (Entry e = header.next; e != header; e = e.next)\r\n clone.add(e.element);\r\n\r\n return clone;\r\n }", "private DataStructure copyAndCut (int min, int max, boolean axis){\r\n\t\tDataStructure newDS = new DataStructure();\r\n\t\tPoint[] regAxis = getPointsInRangeRegAxis(min, max, axis); //O(n)\r\n\t\tPoint[] oppAxis = getPointsInRangeOppAxis(min, max, axis); //O(n)\r\n\t\t\r\n\t\tfor(int i=0; i<regAxis.length ; i++)\r\n\t\t\tnewDS.naiveAddLast(regAxis[i], axis); //O(1) * n times\r\n\t\t\r\n\t\tfor(int i=0; i<oppAxis.length ; i++)\r\n\t\t\tnewDS.naiveAddLast(oppAxis[i], !axis); //O(1) * n times\r\n\t\t\r\n\t\treturn newDS;\r\n\t}", "public void testCloning() throws CloneNotSupportedException {\n TaskSeries s1 = new TaskSeries(\"S1\");\n s1.add(new Task(\"T1\", new Date(1), new Date(2)));\n s1.add(new Task(\"T2\", new Date(11), new Date(22)));\n TaskSeries s2 = new TaskSeries(\"S2\");\n s2.add(new Task(\"T1\", new Date(33), new Date(44)));\n s2.add(new Task(\"T2\", new Date(55), new Date(66)));\n TaskSeriesCollection c1 = new TaskSeriesCollection();\n c1.add(s1);\n c1.add(s2);\n TaskSeriesCollection c2 = (TaskSeriesCollection) c1.clone();\n s1.add(new Task(\"T3\", new Date(21), new Date(33)));\n TaskSeries series = c2.getSeries(\"S1\");\n series.add(new Task(\"T3\", new Date(21), new Date(33)));\n }", "void example4() {\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> list1 = \n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.UINT1.construct(), 100);\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> list2 = \n\t\t\t\tnom.bdezonia.zorbage.storage.Storage.allocate(G.UINT1.construct(), 1000);\n\t\t\n\t\tIndexedDataSource<UnsignedInt1Member> joinedList =\n\t\t\t\tnew ConcatenatedDataSource<>(list1, list2);\n\t\t\n\t\tFill.compute(G.UINT1, G.UINT1.random(), joinedList);\n\t}", "public AudioMetadata copyOf()\n\t{\n\t\tAudioMetadata copy = new AudioMetadata( mSource, mSourceRecordable );\n\t\t\n\t\tcopy.mPriority = mPriority;\n\t\tcopy.mSelected = mSelected;\n\t\tcopy.mRecordable = mRecordable;\n\t\tcopy.mMetadata.addAll( mMetadata );\n\t\tcopy.mUpdated = mUpdated;\n\t\tcopy.mIdentifier = new String( mIdentifier );\n\t\t\n\t\tmUpdated = false;\n\t\t\n\t\treturn copy;\n\t}", "public Copy(DataFrame owner)\n {\n this.owner = owner;\n\n setup();\n }", "public static double[][] copy(double[][] source) {\n if (source == null)\n return null;\n if (source.length < 1)\n return new double[0][0];\n double[][] target = new double[source.length][];\n for (int i = 0; i < source.length; i++) {\n target[i] = new double[source[i].length];\n System.arraycopy(source[i], 0, target[i], 0, source[i].length);\n }\n return target;\n }", "@Override\n public FieldEntity copy()\n {\n return state.copy();\n }", "@Override\r\n\tpublic LogicalValue copy() {\r\n\t\treturn new Pointer(target);\r\n\t}", "private List<ReducedContainer> toReduced(){\n List<ReducedContainer> reduced = new ArrayList<>();\n for(SpecialContainer specialContainer: specialContainers){\n reduced.add(new ReducedContainer(specialContainer.getType(), specialContainer.getCount()));\n }\n\n return reduced;\n\n }", "public static AttributeList cloneAttributeList(AttributeList source) throws IOException, DicomException {\r\n AttributeList dest = new AttributeList();\r\n \r\n ByteArrayOutputStream byteArrayOutputStream = new ByteArrayOutputStream();\r\n DicomOutputStream dicomOutputStream = new DicomOutputStream(byteArrayOutputStream, TransferSyntax.ExplicitVRLittleEndian, TransferSyntax.ExplicitVRLittleEndian);\r\n source.write(dicomOutputStream);\r\n \r\n ByteArrayInputStream byteArrayInputStream = new ByteArrayInputStream(byteArrayOutputStream.toByteArray());\r\n dest.read(new DicomInputStream(byteArrayInputStream));\r\n \r\n return dest;\r\n }", "private void copyArray(Object [] targetArray, Object [] sourceArray) {\n if (targetArray.length < sourceArray.length) {\n for (int i = 0; i < targetArray.length; i++) {\n targetArray[i] = sourceArray[i];\n }\n }\n else {\n for (int i = 0; i < sourceArray.length; i++) {\n targetArray[i] = sourceArray[i];\n }\n }\n }", "public void removeIdenticalDataSources(Collection<DataSource> sources) {\n for (DataSource source:sources) {\n removeIdenticalDataSources(source); \n } \n }", "public static LinkedList<Integer> copyR(ArrayList<Integer> orig, int start, LinkedList<Integer> myList) {\n if(orig.size() == 0 || start >= orig.size()) {\n return myList;\n } else {\n //if bigger, add the element at start into the LinkedList INCLUDE IN RETURN\n myList.addLast(orig.get(start));\n return copyR(orig, start + 1, myList);\n }\n }", "@Override\n\t\tpublic ImmutableSequentialGraph copy() {\n\t\t\treturn new ComposedGraph( g0, g1.copy() );\n\t\t}", "private static <T> void cloneCollection(Collection<T> originalCollection, Collection<T> clonedCollection, PropertyFilter propertyFilter, String... patterns) {\n\t\tJpaCloner jpaCloner = new JpaCloner(propertyFilter);\n\t\tfor (T root : originalCollection) {\n\t\t\tclonedCollection.add(clone(root, jpaCloner, patterns));\n\t\t}\n\t}", "@Override\n public Data clone() {\n final Data data = new Data(name, code, numeric, symbol, fractionSymbol, fractionsPerUnit, rounding, formatString,\n triangulated.clone());\n return data;\n }", "private Shop deepCopy() {\n BookShop obj = null;\n try {\n obj = (BookShop) super.clone();\n List<Book> books = new ArrayList<>();\n Iterator<Book> iterator = this.getBooks().iterator();\n while(iterator.hasNext()){\n\n books.add((Book) iterator.next().clone());\n }\n obj.setBooks(books);\n } catch (CloneNotSupportedException exc) {\n exc.printStackTrace();\n }\n return obj;\n }", "@Test\n public void sharedFilterEnsuresUniqueResults() {\n Filter filter = new Filter(\"test-filter\");\n final Dataset dataset1 = new Dataset(\"TEST1\", \"sql\", filter);\n final Dataset dataset2 = new Dataset(\"TEST2\", \"sql2\", filter); // shared same filter\n\n List<String> entry1 = new ArrayList<>();\n entry1.add(\"001\");\n entry1.add(\"aaa\");\n\n List<String> entry2 = new ArrayList<>();\n entry2.add(\"002\");\n entry2.add(\"bbb\");\n\n List<String> entry3 = new ArrayList<>();\n entry3.add(\"003\");\n entry3.add(\"ccc\");\n\n List<String> entry4 = new ArrayList<>();\n entry4.add(\"004\");\n entry4.add(\"ddd\");\n\n List<List<String>> queryResults1 = new ArrayList<>();\n queryResults1.add(entry1);\n queryResults1.add(entry2);\n queryResults1.add(entry3);\n queryResults1.add(entry4);\n\n List<String> entry5 = new ArrayList<>();\n entry5.add(\"005\"); // different\n entry5.add(\"eee\");\n\n List<String> entry6 = new ArrayList<>();\n entry6.add(\"002\"); // same\n entry6.add(\"bbb\");\n\n List<String> entry7 = new ArrayList<>();\n entry7.add(\"007\"); // different\n entry7.add(\"fff\");\n\n List<String> entry8 = new ArrayList<>();\n entry8.add(\"004\"); // same\n entry8.add(\"ddd\");\n\n List<List<String>> queryResults2 = new ArrayList<>();\n queryResults2.add(entry5);\n queryResults2.add(entry6);\n queryResults2.add(entry7);\n queryResults2.add(entry8);\n\n // given\n dataset1.populateCache(queryResults1, 200L);\n dataset2.populateCache(queryResults2, 300L);\n\n // when\n final List<String> result1 = dataset1.getCachedResult();\n final List<String> result2 = dataset1.getCachedResult();\n final List<String> result3 = dataset1.getCachedResult();\n final List<String> result4 = dataset1.getCachedResult();\n final List<String> result5 = dataset2.getCachedResult();\n final List<String> result6 = dataset2.getCachedResult();\n\n // then\n assertEquals(\"Wrong result 1\", entry1, result1); // first datset is as-is\n assertEquals(\"Wrong result 2\", entry2, result2); // first datset is as-is\n assertEquals(\"Wrong result 3\", entry3, result3); // first datset is as-is\n assertEquals(\"Wrong result 4\", entry4, result4); // first datset is as-is\n assertEquals(\"Wrong result 3\", entry5, result5); // second datset, not filtered out\n assertEquals(\"Wrong result 3\", entry7, result6); // second dataset, entry6 is filtered out\n\n // and\n try {\n dataset1.getCachedResult();\n fail(\"Expected to run out of data\");\n\n } catch (IllegalStateException ex) {\n assertEquals(\"Wrong error\", \"No more data available for dataset: TEST1\", ex.getMessage());\n }\n\n try {\n // entry7 should be filtered out, resulting in no more data\n dataset2.getCachedResult();\n fail(\"Expected to run out of data\");\n\n } catch (IllegalStateException ex) {\n assertEquals(\"Wrong error\", \"No more data available for dataset: TEST2\", ex.getMessage());\n }\n\n // and\n assertEquals(\"Wrong cache size\", Optional.of(4), dataset1.getMetrics().getCacheSize());\n assertEquals(\"Wrong timing\", Optional.of(200L), dataset1.getMetrics().getTimingMilliseconds());\n assertEquals(\"Wrong cache requested\", Optional.of(5), dataset1.getMetrics().getCacheRequested());\n assertEquals(\"Wrong filtered out\", Optional.empty(), dataset1.getMetrics().getFilteredOut());\n\n // and\n assertEquals(\"Wrong cache size\", Optional.of(4), dataset2.getMetrics().getCacheSize());\n assertEquals(\"Wrong timing\", Optional.of(300L), dataset2.getMetrics().getTimingMilliseconds());\n assertEquals(\"Wrong cache requested\", Optional.of(3), dataset2.getMetrics().getCacheRequested());\n assertEquals(\"Wrong filtered out\", Optional.of(2), dataset2.getMetrics().getFilteredOut());\n }", "@Test\n public void testCloning() throws CloneNotSupportedException {\n DefaultPieDataset d1 = new DefaultPieDataset();\n d1.setValue(\"V1\", new Integer(1));\n d1.setValue(\"V2\", null);\n d1.setValue(\"V3\", new Integer(3));\n DefaultPieDataset d2 = (DefaultPieDataset) d1.clone();\n\n assertTrue(d1 != d2);\n assertTrue(d1.getClass() == d2.getClass());\n assertTrue(d1.equals(d2));\n }", "@Override\n\tpublic Instance copy(final double[] values) {\n\t\treturn null;\n\t}", "@Override\n\tpublic directed_weighted_graph copy() {\n\t\tdirected_weighted_graph copy = new DWGraph_DS();\n\t\tCollection<node_data> vertex = dwg.getV();\n\t\tfor (node_data v : vertex) {\n\t\t\tNodeData ver = new NodeData(v.getKey(), v.getLocation(), v.getWeight());\n\t\t\tcopy.addNode(ver);// Add node\n\t\t\tcopy.getNode(v.getKey()).setInfo(v.getInfo());// Set info to node\n\t\t\tcopy.getNode(v.getKey()).setTag(v.getTag());// Set tag to node\n\t\t}\n\n\t\tfor (node_data n : vertex) {\n\t\t\tCollection<edge_data> edges = dwg.getE(n.getKey());\n\t\t\tif (edges != null) {\n\t\t\t\tfor (edge_data e : edges) {// Add all edges (0 or more) by connecting key,dest and weight\n\t\t\t\t\tcopy.connect(e.getSrc(), e.getDest(), e.getWeight());\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn copy;\n\t}", "@Override\n public void resetFilteredLists() {\n\n }", "public abstract INodo copy();", "public DataFrame copy() {\n return new DataFrame(data.values, header.values, index.values);\n }", "default C cloneFlat() {\n\t\treturn clone(FieldGraph.of(getFields()));\n\t}", "public List<E> clone();", "private List<Cloudlet> cloneCloudlets(final Vm sourceVm) {\n final List<Cloudlet> sourceVmCloudlets = sourceVm.getCloudletScheduler().getCloudletList();\n final List<Cloudlet> clonedCloudlets = new ArrayList<>(sourceVmCloudlets.size());\n for (Cloudlet cl : sourceVmCloudlets) {\n clonedCloudlets.add(cloneCloudlet(cl, cl.getLength() - cl.getFinishedLengthSoFar()));\n }\n\n return clonedCloudlets;\n }", "@Test\n public void test_Copy() {\n //This tests the method with default values.\n System.out.println(\"Testing MeasuredRatioModel's copy()\");\n MeasuredRatioModel instance = new MeasuredRatioModel();\n MeasuredRatioModel expectedResult = instance;\n MeasuredRatioModel result = instance.copy();\n assertEquals(expectedResult, result);\n\n //This tests the method with specified values.\n instance=new MeasuredRatioModel(\"hello\",new BigDecimal(\"3.87695\"),\"ABS\",new BigDecimal(\"1.25\"),false,true);\n expectedResult = instance;\n result = instance.copy();\n assertEquals(expectedResult, result);\n }", "@Test\n\tpublic void copy() {\n\t\tBody b1 = new Body();\n\t\tBodyFixture b1f1 = b1.addFixture(Geometry.createCircle(0.5));\n\t\t\n\t\tCollisionItemAdapter<Body, BodyFixture> c1 = this.item.copy();\n\t\tTestCase.assertNull(c1.getBody());\n\t\tTestCase.assertNull(c1.getFixture());\n\t\t\n\t\tthis.item.set(b1, b1f1);\n\t\tCollisionItemAdapter<Body, BodyFixture> c2 = this.item.copy();\n\t\tTestCase.assertEquals(b1, c2.getBody());\n\t\tTestCase.assertEquals(b1f1, c2.getFixture());\n\t\t\n\t\t// make sure it's a deep copy\n\t\tc1.set(null, null);\n\t\tTestCase.assertNull(c1.getBody());\n\t\tTestCase.assertNull(c1.getFixture());\n\t\tTestCase.assertEquals(b1, c2.getBody());\n\t\tTestCase.assertEquals(b1f1, c2.getFixture());\n\t}", "public void copy(ScrapedDocketData that) {\n\t\tsetWestlawClusterName(that.getWestlawClusterName());\n\t\tsetDocketNumber(that.getDocketNumber());\n\t\tsetScrapeType(that.getScrapeType());\n\t\tsetCaseType(that.getCaseType());\n\t\tsetSubdivisionName(that.getSubdivisionName());\n\t\tsetDocketDataFields(that.getDocketDataFields());\n\t\tsetLastScrapeDate(that.getLastScrapeDate());\n\t\tsetLastSourceFilename(that.getLastSourceFilename());\n//\t\tsetScrapedDocketHistories(new java.util.LinkedHashSet<com.trgr.dockets.core.entity.ScrapedDocketHistory>(that.getScrapedDocketHistories()));\n\t}", "public void removeDataSourcesWithSameOrigin(DataSource source) {\n Iterator<DataSource> iter=datasources.iterator();\n while (iter.hasNext()) {\n DataSource old=iter.next();\n if (old.hasSameOrigin(source)) iter.remove();\n }\n }", "public void copyFromNetwork(final FlatNetwork source) {\r\n\t\tEngineArray.arrayCopy(source.getWeights(), this.weights);\r\n\t\tEngineArray.arrayCopy(source.getLayerOutput(), this.output);\r\n\t}" ]
[ "0.62623703", "0.5899936", "0.5874736", "0.5755885", "0.5701255", "0.5602303", "0.5589196", "0.551617", "0.5447543", "0.53621876", "0.53592336", "0.5293107", "0.5219561", "0.5203651", "0.5201828", "0.5196146", "0.5182342", "0.51632017", "0.51394445", "0.5130379", "0.5124973", "0.5094536", "0.50873035", "0.50649995", "0.50575924", "0.5052665", "0.5048785", "0.503866", "0.50324607", "0.49888352", "0.49731004", "0.49698186", "0.4959974", "0.49518043", "0.4950102", "0.49371716", "0.49323243", "0.49241158", "0.4910447", "0.49069393", "0.49033964", "0.49026093", "0.48938075", "0.48799443", "0.4879719", "0.4874664", "0.4874165", "0.48676467", "0.4849173", "0.48350614", "0.48127332", "0.48075753", "0.47910458", "0.4779992", "0.4772147", "0.47679603", "0.4767812", "0.47660813", "0.47645715", "0.47593418", "0.47592863", "0.47553834", "0.47462964", "0.47311535", "0.472546", "0.47231013", "0.4722942", "0.4722597", "0.47153273", "0.47148466", "0.47098103", "0.4708056", "0.47063896", "0.4698441", "0.46944648", "0.469221", "0.46850604", "0.46770728", "0.46720952", "0.46644622", "0.4661271", "0.46553573", "0.46535543", "0.46527472", "0.4651923", "0.46459642", "0.46413994", "0.46304688", "0.46285212", "0.46241596", "0.46212873", "0.46190432", "0.46092045", "0.46089107", "0.4601201", "0.45932212", "0.45900443", "0.4584881", "0.45843154", "0.45777792" ]
0.6687111
0
This method will be called if the game save is initiated
void onGameSaved(File file);
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void saveGame(){\n\t\t\n\t}", "@Override\n public void saveGame() {\n\n }", "public void saveGame() {\n\t\tmanager.saveGame();\n\t}", "public void save(){\r\n\t\ttry {\r\n\t\t\tgame.suspendLoop();\r\n\t\t\tGameStockage.getInstance().save(game);\r\n\t\t\tgame.resumeLoop();\r\n\t\t} catch (GameNotSaveException e) {\r\n\t\t\tSystem.err.println(e.getMessage());\r\n\t\t\tgame.resumeLoop();\r\n\t\t} catch (IOException e) {\r\n\t\t\tSystem.err.println(e.getMessage());\r\n\t\t\tgame.resumeLoop();\r\n\t\t}\r\n\t}", "public void saveGame(){\n \tsaveOriginator.writeMap(this.map, this.getObjectives(), this.gameState);\n \tsaveGame.saveGame(saveOriginator);\n }", "public void SaveCurrentGame(){\n if(gameStarted == false){ return; }\n recordGame.write(board, timeRuunableThread, level);\n timeRuunableThread.setDrawNumber(false);\n canLoadGame = true;\n // update infoCanvas\n CleanInfoCanvas();\n }", "@Override\n public void save(Game game) {\n }", "@Override\r\n\tpublic GameState save() {\n\t\treturn null;\r\n\t}", "private void checkSave() {\n if (view.getSave()) {\n try {\n saveGame.export(view.getSaveGameName());\n } catch (Exception e) {\n System.out.println(\"saving failed\");\n }\n System.exit(0);\n }\n }", "public void saveGame();", "@Override\r\n\tpublic void onPause() {\r\n\t\tsuper.onPause();\r\n\t\ttry {\r\n\t\t\tSaveGameHandler.saveGame(this, new SaveGame(controller, status),\r\n\t\t\t\t\t\"test.game\");\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "void saveGame();", "public void saveGameSession() {\n\t\tlastSaved = ProjectZero.calendar.getTime().toString();\n\t\tAssetHandler.saveGameSession();\n\t}", "void gameSaved() {\n\t\tSystem.out.println(\"\\n\\nGame saved.\");\n\t}", "void saveGame() throws IOException, Throwable {\n Save save = new Save(\"01\");\n save.addToSaveGame(objectsToSave());\n save.saveGame();\n }", "public SaveGame() {\n\t\tlives = 0;\n\t\tscore = 0;\n\t\tbrainX = 0;\n\t\tbrainY = 0;\n\t\tzombieX = 0;\n\t}", "public void save() {\n\t\ttry {\n\t\t\t// use buffering\n\t\t\tOutputStream file = new FileOutputStream(\"games.txt\");\n\t\t\tOutputStream buffer = new BufferedOutputStream(file);\n\t\t\tObjectOutput output = new ObjectOutputStream(buffer);\n\t\t\ttry {\n\t\t\t\tif (gameOver) {\n\t\t\t\t\t//notify no need to save completed game\n\t\t\t\t} else {\n\t\t\t\t\tgames.add(this);\n\t\t\t\t\toutput.writeObject(games);\n\t\t\t\t}\n\t\t\t} finally {\n\t\t\t\toutput.close();\n\t\t\t}\n\t\t} catch (IOException e) {\n\t\t\tSystem.out.println(\"Save not successful\");\n\t\t}\n\t}", "public void save() {\n\t\tthis.setState(Constants.CWorld.STATE_SAVING);\n\t\tthis.getWorld().saveAll();\n\t\tthis.setState(Constants.CWorld.STATE_ONLINE);\n\t}", "public void saveState() \n\t{\n\t\tsuper.saveState();\n\t}", "public void saveState() {\n\t\tsuper.saveState();\n\t}", "public void save()\n\t{\n\t\tif(entity != null)\n\t\t\t((SaveHandler)DimensionManager.getWorld(0).getSaveHandler()).writePlayerData(entity);\n\t}", "public void SaveGame(){\n if(gameStarted == false || canLoadGame == true){ return; }\n gamePaused = true;\n timeRuunableThread.setPause(gamePaused);\n int input = JOptionPane.showOptionDialog(null, \"Do you want to save game?\", \"Save Game\", JOptionPane.OK_CANCEL_OPTION, JOptionPane.INFORMATION_MESSAGE, null, null, null);\n if(input == JOptionPane.OK_OPTION) {\n SaveCurrentGame();\n animationThread.start();\n if(muteMusic == false){\n music.stopPlayingAudio(\"All\");\n music.playAudio(\"LoadingScreenMusic\");\n }\n musicName = \"LoadingScreenMusic\";\n }else{\n gamePaused = false;\n timeRuunableThread.setPause(gamePaused);\n }\n }", "public void save() {\n final JFileChooser fileChooser =\n new JFileChooser(System.getProperty(\"user.dir\"));\n try {\n fileChooser.setSelectedFile(new File(\"save.ser\"));\n int saveFile = fileChooser.showSaveDialog(GameFrame.this);\n\n if (saveFile == JFileChooser.APPROVE_OPTION) {\n File saveGame = fileChooser.getSelectedFile();\n FileOutputStream fileOut = new FileOutputStream(saveGame);\n ObjectOutputStream objOut = new ObjectOutputStream(fileOut);\n objOut.writeObject(world);\n objOut.close();\n fileOut.close();\n System.out.println(\"Game saved.\");\n } else {\n return;\n }\n } catch (IOException i) {\n i.printStackTrace();\n }\n\n }", "@Override\n public void save()\n {\n \n }", "public void save() {\t\n\t\n\t\n\t}", "@Override\n public void save() {\n \n }", "@Override\n public void Save() {\n\t \n }", "void save() {\n gameModelPoDao.saveToFile(file.getAbsolutePath(), gameModelPo);\n }", "@Override\n protected void onSaveInstanceState(Bundle bundle) {\n super.onSaveInstanceState(bundle);\n gameView.saveInstanceState(bundle);\n }", "public static void saveGameType() {\r\n\t\tclearGameType();\r\n\t\t\r\n\t\tif (GameSetup.threeHanded.getState()) {\r\n\t\t\tMain.isThreeHanded = true;\r\n\t\t}\r\n\t\tif (GameSetup.fourHandedSingle.getState()) {\r\n\t\t\tMain.isFourHandedSingle = true;\r\n\t\t}\r\n\t\tif (GameSetup.fourHandedTeams.getState()) {\r\n\t\t\tMain.isFourHandedTeams = true;\r\n\t\t}\r\n\t}", "public boolean isSavingGame() {\n return savingGame;\n }", "@Override\n\tpublic void onSave() {\n\t\tchatFile();\n\t}", "private void saveBeforeRun() {\n if ( _helper != null && _settings.getSaveBeforeRun() )\n _helper.saveBeforeRun();\n }", "@Override\n\tpublic void save() {\n\t\tSystem.out.println(\"save method\");\n\t}", "public void startSavedGame()\n {\n \n // get rid of nl character left in the stream\n // outFile.flush();\n \n // prompt user and get a file path\n System.out.println(\"\\nWhat is the file path?\");\n String filePath = keyboard.next();\n \n // call the getSavedGame( ) method in the GameControl class to load the game\n GameControl gc = new GameControl();\n gc.getSavedGame(filePath);\n\n // display the game menu for the loaded game\n MainMenuView mmv = new MainMenuView();\n mmv.displaySaveGameView();\n }", "@Override\n public void onPause() {\n super.onPause();\n ObjectOutput out = null;\n String fileName = \"savedGame\";\n File saved = new File(getFilesDir(), fileName);\n\n try {\n out = new ObjectOutputStream(new FileOutputStream(saved, false));\n out.writeObject(player);\n out.close();\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }", "@Override\r\n\tpublic void onSave(Bundle outState) {\n\t}", "public void saveGame(){\n updateProperties();\n try {\n output = new FileOutputStream(fileName);\n properties.store(output, null); //saving properties to file\n } catch (IOException e) {\n System.out.println(\"--- FAILED TO SAVE GAME ---\");\n e.printStackTrace();\n } finally {\n if (output != null) {\n try {\n output.close();\n System.out.println(\"--- GAME SAVED ---\");\n } catch (IOException e) {\n System.out.println(\"--- FAILED TO CLOSE OUTPUT ---\");\n e.printStackTrace();\n }\n }\n }\n }", "public void autoSave(){\n\t\ttry {\n\t\t\t//read in file\n\t\t\tFile file = new File(System.getProperty(\"user.dir\")+\"/Default.scalcsave\");\n\t\t\tObjectOutputStream output = new ObjectOutputStream(new FileOutputStream(file));\n\t\t\toutput.writeObject(SaveFile.getSaveFile());\n\t\t\toutput.close();\n\t\t\tSystem.out.println(\"Save Success\");\n\t\t\t\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}", "@Override\n\tpublic void save() {\n\t\t\n\t}", "@Override\n\tpublic void save() {\n\t\t\n\t}", "@RequiresApi(api = Build.VERSION_CODES.O)\n @Override\n public void onPause() {\n SharedPreferences sharedPreferences = getSharedPreferences(MainActivity.sharedPreferencesKey,MODE_PRIVATE);\n SharedPreferences.Editor edit = sharedPreferences.edit();\n GlobalVariables globalVariables = GlobalVariables.getInstance();\n boolean gameStarted = globalVariables.getGameStarted();\n if (gameStarted) {\n try {\n String serializedGame = globalVariables.toString(\"\");\n edit.putString(\"game\", serializedGame);\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n edit.commit();\n super.onPause();\n }", "@Override\n public boolean save()\n {\n return false;\n }", "private void save() {\n var boolGrid = editor.getBoolGrid();\n //Generate a track grid from the bool frid\n var grid = Track.createFromBoolGrid(boolGrid);\n var valid = Track.isValidTrack(grid);\n if (!valid) {\n //fire an error event\n MessageBus.fire(new ErrorEvent(\"Invalid track\", \"\", 2));\n } else {\n //Save the track and pop back\n var generator = new TrackFromGridGenerator(grid);\n var track = generator.generateTrack();\n (new TrackStorageManager()).saveTrack(track);\n menu.navigationPop();\n menu.showError(new ErrorEvent(\"Saved track!\", \"\", 2, Colour.GREEN));\n }\n }", "@Override\n public void onSaveInstanceState(Bundle outState) {\n super.onSaveInstanceState(outState);\n mGameLoop.saveState(outState);\n Log.w(LOG_TAG, \"sIS called\");\n }", "@Override\r\n public void onSaveInstanceState(Bundle savedInstanceState) {\n super.onSaveInstanceState(savedInstanceState);\r\n // Save the user's current game state\r\n savedInstanceState.putInt(\"STEPS\", numSteps);\r\n\r\n }", "private void saveInitialGameLocation() {\n\n\t\tGAME_LIST = new ArrayList<gameLocation>();\n\n\t\tfor (int i = 0; i < NumGameLocation; i++) {\n\t\t\taddNewGame(getGameLocation(i));\n\t\t}\n\t}", "public void doSave() {\n if (isSceneNameChanged()) {\n scene_.setName(nameInput_.getValue());\n }\n scene_.setText(sceneText_.getText());\n }", "private void completeSave() {\n colorBar.updateRevertToCurrent();\n colorBar.revertColorBar();\n undoBtn.setEnabled(false);\n redoBtn.setEnabled(false);\n cmapParams.setColorMapName(seldCmapName);\n saveBtn.setEnabled(true);\n }", "public void save() {\n settingService.saveMaxScore(score);\r\n// powerUpCount = 0;\r\n// powerDownCount = 0;\r\n// purplePowerCount = 0;\r\n// yellowMadnessCount = 0;\r\n// shapeCount = 0;\r\n }", "@Override\n\tpublic JsonElement save(SaveGameRequest SaveRequest) {\n\t\treturn null;\n\t}", "private void save() {\n Saver.saveTeam(team);\n }", "@Override\r\n\tpublic void save() {\n\r\n\t}", "@Override\r\n\tpublic void save() {\n\r\n\t}", "@Override\n\tpublic void posSave() {\n\t\t\n\t}", "@Override\n\tpublic void posSave() {\n\t\t\n\t}", "@Override\n public void save() {\n\n }", "void saveGameState(File saveName);", "public void saveState() { }", "@Override\n public void onPause() {\n super.onPause();\n Log.d(TAG, \"onPause saving layers\");\n }", "public void onSaveListen() {\n _gamesList.get(_gamePos).getPlayers().add(playerName);\n // Increment the number of players that have joined the game\n _gamesList.get(_gamePos).setNumPlayers(_gamesList.get(_gamePos).getNumPlayers() + 1);\n\n TextView playersBlock = (TextView) findViewById(R.id.playersBlock);\n playersBlock.setText(\"\");\n List<String> players = _gamesList.get(_gamePos).getPlayers();\n for(int i = 0; i < players.size(); i++) {\n Log.d(\"GamePlayerSize\", Integer.toString(_gamesList.get(_gamePos).getPlayers().size()));\n if (i < players.size() - 1) {\n playersBlock.append(players.get(i) + \", \");\n }\n else {\n // Don't put a comma after the last one\n playersBlock.append(players.get(i));\n }\n }\n\n // Update the shared preferences with the edited game\n SharedPreferences gamesPref = this.getSharedPreferences(GAMES_FILE, MODE_PRIVATE);\n Gson gson = new Gson();\n\n SharedPreferences.Editor prefsEditor = gamesPref.edit();\n\n // Convert the games list into a json string\n String json = gson.toJson(_gamesList);\n Log.d(\"MainActivity\", json);\n\n // Update the _gamesMasterList with the modified _game\n prefsEditor.putString(GAME_KEY, json);\n prefsEditor.commit();\n\n Context context = getApplicationContext();\n CharSequence text = \"You have joined the game!\";\n int duration = Toast.LENGTH_SHORT;\n\n Toast toast = Toast.makeText(context, text, duration);\n toast.show();\n }", "protected void doSave() {\n GWT.log(\"Please override\");\n }", "@Override\r\n\tpublic void updateGameFinished() {\n\t\t\r\n\t}", "void save() {\r\n if (actionCompleted) {\r\n forget();\r\n } else {\r\n AccountSettings.stateStored = new Bundle();\r\n save(AccountSettings.stateStored);\r\n }\r\n }", "public void alertSaveSuccess() {\n\t\tthis.alert(\"Saved\",\"Game saved\",AlertType.INFORMATION);\n\t}", "int needsSaving();", "public void finishGame(){\r\n\t\t\t\tgameStarted = false;\r\n\t\t\t}", "@Override\n public int saveGame(String foo) {\n RunGame.saveGameToDisk(foo);\n return 0;\n }", "public void saveGame(File fileLocation);", "@Override\n\tprotected void onPause() {\n\t super.onPause();\n\t this.saveInFile();\n\t}", "public void save() {\n savePrefs();\n }", "void notifyGameRestored();", "private void save() {\n Tile[][] field = gameController.grid.field;\n Tile[][] undoField = gameController.grid.undoField;\n// SharedPreferenceUtil.put(this, SpConstant.WIDTH, field.length);\n// SharedPreferenceUtil.put(this, SpConstant.HEIGHT, field.length);\n for (int xx = 0; xx < field.length; xx++) {\n for (int yy = 0; yy < field[0].length; yy++) {\n if (field[xx][yy] != null) {\n SharedPreferenceUtil.put(this, xx + \"_\" + yy, field[xx][yy].getValue());\n } else {\n SharedPreferenceUtil.put(this, xx + \"_\" + yy, 0);\n }\n\n if (undoField[xx][yy] != null) {\n SharedPreferenceUtil.put(this, SpConstant.UNDO_GRID + xx + \"_\" + yy, undoField[xx][yy].getValue());\n } else {\n SharedPreferenceUtil.put(this, SpConstant.UNDO_GRID + xx + \"_\" + yy, 0);\n }\n }\n }\n SharedPreferenceUtil.put(this, SpConstant.SCORE, gameController.currentScore);\n SharedPreferenceUtil.put(this, SpConstant.HIGH_SCORE_TEMP, gameController.historyHighScore);\n SharedPreferenceUtil.put(this, SpConstant.UNDO_SCORE, gameController.lastScore);\n SharedPreferenceUtil.put(this, SpConstant.CAN_UNDO, gameController.canUndo);\n SharedPreferenceUtil.put(this, SpConstant.GAME_STATE, gameController.gameState);\n SharedPreferenceUtil.put(this, SpConstant.UNDO_GAME_STATE, gameController.lastGameState);\n SharedPreferenceUtil.put(this, SpConstant.AUDIO_ENABLED, gameController.isAudioEnabled);\n }", "public static void save() {\n Game.save(UI.askNgetString(\"Filename for this save file?\")+\".xml\");\n }", "@Override\n public void loadGame() {\n\n }", "public static void runSaveState() {\n for (GUISaveable s: saveables) {\n s.saveState();\n }\n }", "public void requestSavePose() \r\n {\r\n \r\n \t// DON'T ASK, JUST SAVE\r\n boolean savedSuccessfully = poseIO.savePose(currentFile, false);\r\n if (savedSuccessfully)\r\n {\r\n \tposeIO.savePoseImage(currentPoseName, poseID);\r\n // MARK IT AS SAVED\r\n saved = true;\r\n \r\n // AND REFRESH THE GUI\r\n AnimatedSpriteEditor singleton = AnimatedSpriteEditor.getEditor(); \r\n \r\n PoseurStateManager poseurStateManager = singleton.getStateManager().getPoseurStateManager();\r\n poseurStateManager.clearSelectShape();\r\n poseurStateManager.setState(PoseurState.SELECT_SHAPE_STATE);\r\n \r\n }\r\n }", "private void saveGame(int gameId, String fileName){\n\n }", "public void onMenuSave() {\n String lastSavedPath = controller.getLastSavePath();\n\n if (lastSavedPath == null) {\n onMenuSaveAs();\n return;\n }\n\n handleFileStorageFactoryResult(controller.saveFile(lastSavedPath));\n }", "private void save() {\r\n\t\tif (Store.save()) {\r\n\t\t\tSystem.out.println(\" > The store has been successfully saved in the file StoreData.\\n\");\r\n\t\t} else {\r\n\t\t\tSystem.out.println(\" > An error occurred during saving.\\n\");\r\n\t\t}\r\n\t}", "@Override\n\tpublic void create () {\n\t\t\n\t\teManager = new EventManager();\n\t\t\n\t\tbatch = new SpriteBatch();\n\t\timg = new Texture(\"background.png\");\n\t\t\n\t\tmessages = new MessageManager(eManager);\n\t\t\n\t\tworld = new WorldRenderer(messages, eManager);\n\t\t\n\t\t\n\t\tResourceLoader.getInstance();\n\t\twhile (!ResourceLoader.assetManager.update())\n {\n\t\t\t\n }\n\t\tSystem.gc();\n\t\tsaveLoaded = false;\n\t\t\n\t\ttry{\n\t\t\tplayer = GameSave.loadPlayerSave();\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\t\n\t\t\tplayer.setItems(GameSave.loadPlayerItemsSave());\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\tplayer.setLinkmon(GameSave.loadLinkmonSave());\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\tplayer.getLinkmon().setStats(GameSave.loadLinkmonStatsSave());\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\tplayer.getLinkmon().setBirthDate(GameSave.loadLinkmonBirthDateSave());\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\tGameSave.updateLinkmon(player.getLinkmon());\n\t\t\tSystem.gc();\n\t\t\tThread.sleep(100);\n\t\t\tsaveLoaded = true;\n\t\t} catch(Exception e) {\n\t\t\tsaveLoaded = false;\n\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadPlayerSave\");\n\t\t}\n\t\t\n//\t\ttry{\n//\t\t\tplayer = GameSave.loadPlayerSave();\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadPlayerSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tplayer.setItems(GameSave.loadPlayerItemsSave());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadPlayerItemsSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tplayer.setLinkmon(GameSave.loadLinkmonSave());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadLinkmonSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tplayer.getLinkmon().setStats(GameSave.loadLinkmonStatsSave());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadLinkmonStatsSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tplayer.getLinkmon().setBirthDate(GameSave.loadLinkmonBirthDateSave());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadLinkmonBirthDateSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tplayer.getLinkmon().setPoopList(GameSave.loadPoopSave());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"loadPoopSave\");\n//\t\t}\n//\t\ttry{\n//\t\t\tGameSave.updateLinkmon(player.getLinkmon());\n//\t\t} catch(Exception e) {\n//\t\t\tsaveLoaded = false;\n//\t\t\tGdx.app.log(\"GameClass (LoadingSave)\", \"updateLinkmon\");\n//\t\t}\n\t\t\n\t\t\n\t\t\n\t\tString message = \"\" + Gdx.graphics.getWidth() + \" \" + Gdx.graphics.getHeight();\n Gdx.app.log(\"TIMER\", message);\n\t\t\n\t\tim = new InputMultiplexer();\n\t\t\n\t\tim.addProcessor(world.stage);\n\t\tGdx.input.setInputProcessor(im);\n\t\t\n\t\tif(!saveLoaded) {\n\t\t\tthis.setScreen(new IntroScreen(this, world.ui, eManager));\n\t\t\t//startGame(\"Kilst\", 1);\n\t\t}\n\t\telse {\n//\t\t\tcontrollerService = new ControllerService(this, world.ui, Gdx.graphics.getWidth(), Gdx.graphics.getHeight(), eManager);\n//\t\t\tworld.addLinkmonToWorld(controllerService.getLinkmonController());\n//\t\t\teManager.notify(new ControllerEvent(ControllerEvents.SWAP_SCREEN, ScreenType.MAIN_UI));\n\t\t\tloadGame(player);\n\t\t\t\n\t\t}\n\t}", "public void saving() {\n\t\tSystem.out.println(\"7\");\n\n\t}", "public String saveCurrentGameState() {\r\n\t\treturn null;\r\n\t}", "public void save() {\n }", "public void saveGame() {\r\n\t\t//separator used by system\r\n\t\tString separator = System.getProperty(\"file.separator\");\r\n\t\t//path to where files will be saved\r\n\t\tString path = System.getProperty(\"user.dir\") + separator + \"src\" + separator + \"GameFiles\" + separator;\r\n\r\n\t\ttry {\r\n\r\n\t\t\t//Save the world objects\r\n\t\t\tString world_objects_name = EnvironmentVariables.getTitle() + \"WorldObjects\";\r\n\t\t\t//create a new file with name given by user with added text for identification\r\n\t\t\tFile world_objects_file = new File(path + world_objects_name + \".txt\");\r\n\t\t\tFileOutputStream f_world_objects = new FileOutputStream(world_objects_file);\r\n\t\t\tObjectOutputStream o_world_objects = new ObjectOutputStream(f_world_objects);\r\n\r\n\t\t\t//loop through list and write each object to file\r\n\t\t\tfor(GameObject obj: EnvironmentVariables.getWorldObjects()) {\r\n\t\t\t\to_world_objects.writeObject(obj);\r\n\t\t\t}\r\n\r\n\t\t\to_world_objects.flush();\r\n\t\t\to_world_objects.close();\r\n\t\t\tf_world_objects.flush();\r\n\t\t\tf_world_objects.close();\r\n\t\t\t\r\n\t\t\t\r\n\t\t\t//Save terrain is done the same ass world objects but we create a new file \r\n\t\t\t//with different added text\r\n\t\t\tString terrain_name = EnvironmentVariables.getTitle() + \"Terrain\";\r\n\t\t\tFile terrain_file = new File(path + terrain_name + \".txt\");\r\n\t\t\tFileOutputStream f_terrain = new FileOutputStream(terrain_file);\r\n\t\t\tObjectOutputStream o_terrain = new ObjectOutputStream(f_terrain);\r\n\r\n\t\t\tfor(GameObject obj: EnvironmentVariables.getTerrain()) {\r\n\t\t\t\to_terrain.writeObject(obj);\r\n\t\t\t}\r\n\r\n\t\t\to_terrain.flush();\r\n\t\t\to_terrain.close();\r\n\t\t\tf_terrain.flush();\r\n\t\t\tf_terrain.close();\r\n\t\t\t\r\n\t\t\t//Save main player, given own file but just a single object\r\n\t\t\tString main_player_name = EnvironmentVariables.getTitle() + \"MainPlayer\";\r\n\t\t\tFile main_player_file = new File(path + main_player_name + \".txt\");\r\n\t\t\tFileOutputStream f_main_player = new FileOutputStream(main_player_file);\r\n\t\t\tObjectOutputStream o_main_player = new ObjectOutputStream(f_main_player);\r\n\r\n\t\t\to_main_player.writeObject(EnvironmentVariables.getMainPlayer());\r\n\r\n\t\t\to_main_player.flush();\r\n\t\t\to_main_player.close();\r\n\t\t\tf_main_player.flush();\r\n\t\t\tf_main_player.close();\r\n\t\t\t\r\n\r\n\t\t} catch (FileNotFoundException e) {\r\n\t\t\tSystem.out.println(\"File not found\");\r\n\t\t}\r\n\t\tcatch (IOException e) {\r\n\t\t\tSystem.out.println(\"Error initializing stream\");\r\n\t\t} \r\n\t\t\r\n\t\t//saving the environment variables\r\n\t\ttry {\r\n\t\t\tString env_name = EnvironmentVariables.getTitle() + \"EnvVariables\";\r\n\t\t\tFile env_file = new File(path + env_name + \".txt\");\r\n\t\t\t\r\n\t\t\tif(!env_file.exists()) {\r\n\t\t\t\tenv_file.createNewFile();\r\n\t\t }\r\n\t\t\t \r\n\t\t\t//FileWriter fw = new FileWriter(env_file);\r\n\t\t\tBufferedWriter bw = new BufferedWriter(new FileWriter(env_file));\r\n\t\t\t//write each variable to a new line as a string\r\n\t\t\tbw.write(EnvironmentVariables.getTitle()); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getWidth())); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getHeight())); bw.newLine();\r\n\t\t\tbw.write(EnvironmentVariables.getPlanet()); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getMass())); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getRadius())); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getAirDensity())); bw.newLine();\r\n\t\t\tbw.write(Float.toString(EnvironmentVariables.getMeter())); bw.newLine();\r\n\r\n\t\t\t\r\n\t\t\t//bw.flush();\r\n\t\t\tbw.close();\r\n\t\t\t\r\n\t\t}catch (IOException e) {\r\n\t\t\tSystem.out.println(\"Error initializing stream\");\r\n\t\t}\r\n\t\t\r\n\t\tEnvironmentVariables.getTerrain().clear();\r\n\t\tEnvironmentVariables.getWorldObjects().clear();\r\n\t}", "@Override\n\tpublic void OnGameEnd() {\n\t\tsuper.OnGameEnd();\n\t}", "public static void save(){\n\t\ttry{\n\t\t\tFile f=new File(Constants.PATH+\"\\\\InitializeData\\\\battlesavefile.txt\");\n\t\t\tPrintWriter pw=new PrintWriter(f);\n\t\t\tpw.println(turn);\n\t\t\tpw.println(opponent.toString());\n\t\t\tfor(Unit u:punits){\n\t\t\t\tpw.println(u.toString());\n\t\t\t}\n\t\t\tpw.println(\"End Player Units\");\n\t\t\tfor(Unit u:ounits){\n\t\t\t\tpw.println(u.toString());\n\t\t\t}\n\t\t\tpw.println(\"End Opponent Units\");\n\t\t\tpw.println(priorities);\n\t\t\tpw.println(Arrays.asList(xpgains));\n\t\t\tpw.println(spikesplaced+\" \"+numpaydays+\" \"+activeindex+\" \"+activeunit.getID()+\" \"+weather+\" \"+weatherturn);\n\t\t\tpw.println(bfmaker.toString());\n\t\t\tpw.close();\n\t\t}catch(Exception e){e.printStackTrace();}\n\t}", "@Override\r\n\t\t\tprotected void saveContext() {\n\t\t\t\t\r\n\t\t\t}", "public boolean save() {\n return false;\n }", "public void doSave() {\n WaveformLoader.doSave(waveform, WaveformLoader.scalingForSavingFile);\n }", "@Override\n\tpublic void saveSettings() {\n\n\t}", "public void finishGame() {\r\n gameFinished = true;\r\n }", "public static void save()\n\t{\n writeMap();\n\t}", "public void save(){\r\n if (inputValidation()) {\r\n if (modifyingPart) {\r\n saveExisting();\r\n } else {\r\n saveNew();\r\n }\r\n closeWindow();\r\n }\r\n\r\n }", "private void saveData() {\n }", "private void btnSaveActionPerformed(java.awt.event.ActionEvent evt) {\n rom.save(obstacle, frog);\n isSaved = true;\n }", "@Override\n\t\tpublic void finishIteration() {\n\t\t\trailroad.save();\n\t\t\tSystem.out.println(\"SAVING!\");\n\t\t\tsuper.finishIteration();\n\t\t}", "@Override\n public void onStop() {\n super.onStop();\n ObjectOutput out = null;\n String fileName = \"savedGame\";\n File saved = new File(getFilesDir(), fileName);\n\n try {\n out = new ObjectOutputStream(new FileOutputStream(saved, false));\n out.writeObject(player);\n out.close();\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }", "@Override\n public void save() {\n graphicsEnvironmentImpl.save(canvas);\n }", "private void saveFunction() {\n }" ]
[ "0.8215079", "0.8104656", "0.8043186", "0.7708531", "0.7642311", "0.76330304", "0.760488", "0.74920946", "0.74377453", "0.7423733", "0.74026644", "0.7386086", "0.7372519", "0.7254897", "0.7234319", "0.70975846", "0.70202607", "0.69878864", "0.6987097", "0.69796824", "0.6949788", "0.69489205", "0.69084746", "0.6890118", "0.68791723", "0.6871997", "0.68701303", "0.6866045", "0.6799348", "0.6795272", "0.6792673", "0.6784389", "0.67839754", "0.6780017", "0.67738056", "0.6763295", "0.6751785", "0.67470044", "0.6735758", "0.670766", "0.670766", "0.67066884", "0.6699363", "0.66897786", "0.6688142", "0.66857785", "0.6680867", "0.66763216", "0.6665225", "0.66639125", "0.666389", "0.6661312", "0.6637874", "0.6637874", "0.6634498", "0.6634498", "0.6627047", "0.66072184", "0.66001445", "0.6599327", "0.65855575", "0.6579602", "0.65660906", "0.6560915", "0.65487224", "0.65462095", "0.6537781", "0.65266705", "0.65141225", "0.6507237", "0.6503909", "0.64947915", "0.64846206", "0.6482511", "0.64699364", "0.64592373", "0.64547676", "0.6445477", "0.64363754", "0.641424", "0.6410792", "0.6404791", "0.64021075", "0.64013976", "0.63979757", "0.63815314", "0.63789535", "0.6372313", "0.636946", "0.63674134", "0.6351724", "0.6348601", "0.6346663", "0.6342275", "0.63135564", "0.6306555", "0.63049513", "0.63011134", "0.6293479", "0.6292262" ]
0.7099397
15
TODO jenia: was a pointer
public ME_Model() { _nheldout = 0; _early_stopping_n = 0; _ref_modelp = null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void func_104112_b() {\n \n }", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "public abstract void mo70713b();", "protected boolean func_70814_o() { return true; }", "public final void mo51373a() {\n }", "public void method_4270() {}", "public void mo38117a() {\n }", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n public void perish() {\n \n }", "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "public abstract Object mo1771a();", "private void m50366E() {\n }", "@Override\r\n\t\t\tpublic void func02() {\n\t\t\t\t\r\n\t\t\t}", "public abstract Object mo26777y();", "public abstract void mo27385c();", "public abstract void mo27386d();", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\n protected JsonNode _at(JsonPointer ptr) {\n return null;\n }", "public void smell() {\n\t\t\n\t}", "private void assignment() {\n\n\t\t\t}", "private static void cajas() {\n\t\t\n\t}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "public abstract void mo6549b();", "public void gored() {\n\t\t\n\t}", "@Override\r\n\tpublic void visit(PointerExpression pointerExpression) {\n\r\n\t}", "public abstract void mo56925d();", "public abstract Object mo1185b();", "@Override\n\tpublic void one() {\n\t\t\n\t}", "@Override\n\tpublic void anular() {\n\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "@Override\n public int describeContents() { return 0; }", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "public abstract void mo27464a();", "protected abstract Set method_1559();", "public void mo4359a() {\n }", "public abstract void mo35054b();", "Exp getPointerExp();", "@Override\n\tprotected void GetDataFromNative() {\n\t\t\n\t}", "@Override\n\tprotected void GetDataFromNative() {\n\t\t\n\t}", "public void mo21779D() {\n }", "void mo57277b();", "public boolean isPointer() {return true;}", "public abstract void mo1184a(Object obj);", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\r\n\tvoid func04() {\n\t\t\r\n\t}", "public abstract void mo42329d();", "private void poetries() {\n\n\t}", "public abstract void mo53562a(C18796a c18796a);", "private void strin() {\n\n\t}", "@Override\n\tprotected void interr() {\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "private void kk12() {\n\n\t}", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public void mo55254a() {\n }", "@Override\n protected void prot() {\n }", "public void ref() {\n\n\t}", "public abstract String mo118046b();", "public abstract void mo30696a();", "@Override\n public void memoria() {\n \n }", "@Override\r\n\tprotected void func03() {\n\t\t\r\n\t}", "@Override\n public byte[] recDirect() {\n return null;\n }", "@Override public int describeContents() { return 0; }", "public void mo12930a() {\n }", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "public abstract String mo13682d();", "public abstract String mo41079d();", "public abstract void mo42330e();", "@Override\n\tprotected void getData() {\n\t\t\n\t}", "protected boolean func_70041_e_() { return false; }", "public void mo21877s() {\n }", "public void mo21791P() {\n }", "public long getFilePointer() {\n/* 141 */ return this.pointer;\n/* */ }", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "public void mo21787L() {\n }", "public void mo21825b() {\n }", "public void mo6081a() {\n }", "private stendhal() {\n\t}", "@Override\n public void function()\n {\n }", "@Override\n public void function()\n {\n }", "public abstract String mo83558a(Object obj);", "public abstract void mo42331g();", "public void m23075a() {\n }", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "public void mo21793R() {\n }", "@Override\n\tpublic void einkaufen() {\n\t}", "public void skystonePos4() {\n }", "public void mo6944a() {\n }", "@Override\n\tpublic void emprestimo() {\n\n\t}", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "zzafe mo29840Y() throws RemoteException;", "public void mo9848a() {\n }", "public void mo97908d() {\n }", "@Override\n\tprotected void getExras() {\n\n\t}" ]
[ "0.5797176", "0.55860627", "0.5584094", "0.5535476", "0.5533396", "0.552574", "0.55119574", "0.5470522", "0.54522175", "0.54361904", "0.5427765", "0.5373425", "0.5360333", "0.5360142", "0.53562456", "0.5353352", "0.5345733", "0.5340423", "0.5331016", "0.53127885", "0.5311131", "0.53042346", "0.5302589", "0.5302144", "0.5287292", "0.5286616", "0.5275175", "0.5271618", "0.52619135", "0.52553797", "0.52452177", "0.52452177", "0.52452177", "0.52452177", "0.52452177", "0.52452177", "0.52452177", "0.5239142", "0.52284515", "0.52204525", "0.5213524", "0.5210228", "0.52000505", "0.51999557", "0.519811", "0.519811", "0.5197515", "0.51869285", "0.51853013", "0.5182911", "0.51817", "0.51782036", "0.51760215", "0.5174174", "0.5169305", "0.5169004", "0.5159668", "0.51560086", "0.51560086", "0.5155971", "0.5148447", "0.5147321", "0.51451683", "0.51419735", "0.51407814", "0.5138476", "0.513242", "0.5128985", "0.51274383", "0.51235855", "0.5117815", "0.51172477", "0.51159793", "0.51144093", "0.51054347", "0.5097328", "0.50904006", "0.508856", "0.5086815", "0.50855905", "0.5085269", "0.5084172", "0.50740415", "0.50738174", "0.5071593", "0.50697803", "0.50697803", "0.50661045", "0.5062384", "0.5061496", "0.50592804", "0.5059029", "0.50559765", "0.50532633", "0.50407726", "0.5038414", "0.5035522", "0.5029718", "0.50264454", "0.5017321", "0.50146973" ]
0.0
-1
public void get_features(list, Double> > & fl);
public void set_heldout(final int h, final int n) { _nheldout = h; _early_stopping_n = n; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "List<Feature> getFeatures();", "List<IFeature> getFeatureList();", "java.util.List<iet.distributed.telemetry.Feature> \n getFeatureList();", "java.util.List<java.lang.Float> getInList();", "java.util.List<org.landxml.schema.landXML11.FeatureDocument.Feature> getFeatureList();", "java.util.List<org.landxml.schema.landXML11.FeatureDocument.Feature> getFeatureList();", "public double getFeature(int i) {\n\t return _features[i];\r\n\t//return 0;\r\n}", "public java.util.List<org.landxml.schema.landXML11.FeatureDocument.Feature> getFeatureList()\r\n {\r\n final class FeatureList extends java.util.AbstractList<org.landxml.schema.landXML11.FeatureDocument.Feature>\r\n {\r\n public org.landxml.schema.landXML11.FeatureDocument.Feature get(int i)\r\n { return SurfaceImpl.this.getFeatureArray(i); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature set(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = SurfaceImpl.this.getFeatureArray(i);\r\n SurfaceImpl.this.setFeatureArray(i, o);\r\n return old;\r\n }\r\n \r\n public void add(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n { SurfaceImpl.this.insertNewFeature(i).set(o); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature remove(int i)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = SurfaceImpl.this.getFeatureArray(i);\r\n SurfaceImpl.this.removeFeature(i);\r\n return old;\r\n }\r\n \r\n public int size()\r\n { return SurfaceImpl.this.sizeOfFeatureArray(); }\r\n \r\n }\r\n \r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return new FeatureList();\r\n }\r\n }", "public java.util.List<org.landxml.schema.landXML11.FeatureDocument.Feature> getFeatureList()\r\n {\r\n final class FeatureList extends java.util.AbstractList<org.landxml.schema.landXML11.FeatureDocument.Feature>\r\n {\r\n public org.landxml.schema.landXML11.FeatureDocument.Feature get(int i)\r\n { return IntersectionImpl.this.getFeatureArray(i); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature set(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = IntersectionImpl.this.getFeatureArray(i);\r\n IntersectionImpl.this.setFeatureArray(i, o);\r\n return old;\r\n }\r\n \r\n public void add(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n { IntersectionImpl.this.insertNewFeature(i).set(o); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature remove(int i)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = IntersectionImpl.this.getFeatureArray(i);\r\n IntersectionImpl.this.removeFeature(i);\r\n return old;\r\n }\r\n \r\n public int size()\r\n { return IntersectionImpl.this.sizeOfFeatureArray(); }\r\n \r\n }\r\n \r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return new FeatureList();\r\n }\r\n }", "java.util.List<java.lang.String> getFeaturesList();", "public interface SpLocalFeatureList <T extends SpLocalFeature<?, ?>> extends SpRandomisableList<T>, Writeable {\n\n /** The header used when writing LocalFeatureLists to streams and files */\n public static final byte[] BINARY_HEADER = \"KPT\".getBytes();\n\n /**\n * Get the feature-vector data of the list as a two-dimensional array of\n * data. The number of rows will equal the number of features in the list,\n * and the type &lt;Q&gt;must be compatible with the data type of the features\n * themselves.\n *\n * @param <Q>\n * the data type\n * @param a\n * the array to fill\n * @return the array, filled with the feature-vector data.\n */\n public <Q> Q[] asDataArray(Q[] a);\n\n /**\n * Get the length of the feature-vectors of each local feature if they are\n * constant.\n *\n * This value is used as instantiate new local features in the case that the\n * local feature has a constructor that takes a single integer.\n *\n * @return the feature-vector length\n */\n public int vecLength();\n\n @Override\n public SpLocalFeatureList<T> subList(int fromIndex, int toIndex);\n\n}", "public java.util.List<org.landxml.schema.landXML11.FeatureDocument.Feature> getFeatureList()\r\n {\r\n final class FeatureList extends java.util.AbstractList<org.landxml.schema.landXML11.FeatureDocument.Feature>\r\n {\r\n public org.landxml.schema.landXML11.FeatureDocument.Feature get(int i)\r\n { return GPSSetupImpl.this.getFeatureArray(i); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature set(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = GPSSetupImpl.this.getFeatureArray(i);\r\n GPSSetupImpl.this.setFeatureArray(i, o);\r\n return old;\r\n }\r\n \r\n public void add(int i, org.landxml.schema.landXML11.FeatureDocument.Feature o)\r\n { GPSSetupImpl.this.insertNewFeature(i).set(o); }\r\n \r\n public org.landxml.schema.landXML11.FeatureDocument.Feature remove(int i)\r\n {\r\n org.landxml.schema.landXML11.FeatureDocument.Feature old = GPSSetupImpl.this.getFeatureArray(i);\r\n GPSSetupImpl.this.removeFeature(i);\r\n return old;\r\n }\r\n \r\n public int size()\r\n { return GPSSetupImpl.this.sizeOfFeatureArray(); }\r\n \r\n }\r\n \r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return new FeatureList();\r\n }\r\n }", "public double[] getDoubleList();", "List<String> getFeatures();", "java.util.List<org.landxml.schema.landXML11.PlanFeatureDocument.PlanFeature> getPlanFeatureList();", "org.landxml.schema.landXML11.FeatureDocument.Feature getFeatureArray(int i);", "org.landxml.schema.landXML11.FeatureDocument.Feature getFeatureArray(int i);", "java.util.List<? extends iet.distributed.telemetry.FeatureOrBuilder> \n getFeatureOrBuilderList();", "java.util.List<java.lang.Double> getFileList();", "List<FeatureDistribution> asFeatureDistributions();", "public FeatureSet getFeatures() {\n\treturn features;\n }", "private static List<Feature> getFeatures(List<String> row) {\n\t\tString sex = row.get(0);\n\t\tdouble length = Double.parseDouble(row.get(1));\n double diameter = Double.parseDouble(row.get(2));\n double height = Double.parseDouble(row.get(3));\n// double whole_height = Double.parseDouble(row.get(4));\n// double shucked_height = Double.parseDouble(row.get(5));\n double viscera_weight = Double.parseDouble(row.get(6));\n double shell_weight = Double.parseDouble(row.get(7));\n\t\tList<Feature> features = new ArrayList<Feature>();\n\t\tfeatures.add(new NominalFeature(sex));\n\t\tfeatures.add(new ContinuousFeature(length));\n\t\tfeatures.add(new ContinuousFeature(diameter));\n\t\tfeatures.add(new ContinuousFeature(height));\n//\t\tfeatures.add(new ContinuousFeature(whole_height));\n//\t\tfeatures.add(new ContinuousFeature(shucked_height));\n\t\tfeatures.add(new ContinuousFeature(viscera_weight));\n\t\tfeatures.add(new ContinuousFeature(shell_weight));\n\t\treturn features;\n\t}", "private static void caso4(ArrayList<Float> listaValores) {\n \n }", "public interface FeatureFunction {\n double value(Vector vector, MultiLabel multiLabel);\n}", "public org.apache.spark.ml.param.ParamPair<double[]> w (java.util.List<java.lang.Double> value) { throw new RuntimeException(); }", "org.landxml.schema.landXML11.FeatureDocument.Feature[] getFeatureArray();", "org.landxml.schema.landXML11.FeatureDocument.Feature[] getFeatureArray();", "public static Vector TEST_LIST(Feature f) {\n\n Vector v = new Vector();\n if (IS_CONTINUOUS(f.type)) {\n if (f.dmax - f.dmin <= 0.0) {\n v = null;\n } else {\n double vmin = f.dmin;\n double vmax = f.dmax;\n double delta = (vmax - vmin) / ((double) (NUMBER_CONTINUOUS_TIES + 1));\n double vcur = vmin + delta;\n int i;\n for (i = 0; i < NUMBER_CONTINUOUS_TIES; i++) {\n v.addElement(new Double(vcur));\n vcur += delta;\n }\n }\n } else if (IS_INTEGER(f.type)) {\n if (f.imax - f.imin <= 0) {\n v = null;\n } else {\n int vmin = f.imin;\n int nvals = f.imax - f.imin;\n int i;\n for (i = 0; i < nvals; i++) {\n v.addElement(new Integer(vmin + i));\n }\n }\n } else if (IS_NOMINAL(f.type)) {\n if (!Discriminator_Tree.RANDOMISE_SPLIT_FINDING_WHEN_TOO_MANY_SPLITS)\n v = Utils.ALL_NON_TRIVIAL_SUBSETS(f.modalities);\n else if (f.modalities.size() <= Discriminator_Tree.MAX_CARD_MODALITIES_BEFORE_RANDOMISATION)\n v = Utils.ALL_NON_TRIVIAL_SUBSETS(f.modalities);\n else\n v =\n Utils.ALL_NON_TRIVIAL_BOUNDED_SUBSETS(\n f.modalities, Discriminator_Tree.MAX_SIZE_FOR_RANDOMISATION);\n if (v.size() == 0) v = null;\n }\n\n return v;\n }", "public abstract ArrayList< Double > getObjectiveCoefs();", "private static List<IFeature> parseFeatures(WMElement features) {\n List<IFeature> trainingFeatures = new ArrayList<>();\n for (int i = 0; i < features.ConvertToIdentifier().GetNumberChildren(); i++) {\n IFeature res;\n WMElement curFeatureType = features.ConvertToIdentifier().GetChild(i);\n WMElement curFeature = curFeatureType.ConvertToIdentifier().GetChild(0);\n String featureName = curFeature.GetAttribute();\n String featureVal = curFeature.GetValueAsString();\n double featureValNumerical = -1.0;\n try {\n featureValNumerical = Double.parseDouble(featureVal);\n } catch (Exception e) {\n if (featureVal.equalsIgnoreCase(\"true\")) {\n featureValNumerical = 1.0;\n } else if (featureVal.equalsIgnoreCase(\"false\")) {\n featureValNumerical = 0.0;\n }\n }\n\n switch (curFeatureType.GetAttribute()) {\n case \"boolean\":\n res = new BooleanFeature(featureName, featureValNumerical);\n break;\n case \"numerical\":\n res = new NumericalFeature(featureName, featureValNumerical);\n break;\n case \"categorical\":\n res = new CategoricalFeature(featureName, featureVal);\n break;\n default:\n throw new IllegalArgumentException(\"Given feature type is not supported.\");\n }\n\n trainingFeatures.add(res);\n }\n return trainingFeatures;\n }", "public Feature[] getFeatures() throws JsonMappingException, IOException {\n \tfinal String uri = \"http://localhost:12300/featureflags\";\n RestTemplate restTemplate = new RestTemplate();\n HttpHeaders headers = new HttpHeaders();\n headers.setAccept(Arrays.asList(MediaType.APPLICATION_JSON));\n HttpEntity<String> entity = new HttpEntity<String>(\"parameters\", headers);\n ResponseEntity<String> result = restTemplate.exchange(uri, HttpMethod.GET, entity, String.class);\n String body = result.getBody();\n ObjectMapper mapper = new ObjectMapper();\n Feature[] features = mapper.readValue(body, Feature[].class);\n return features;\n }", "java.util.List<java.lang.Float> getNotInList();", "Feature[] extractFeatures(LensResult facet, NaiscListener log);", "ArrayList<Feature> getFeatures(String userid, String project)throws Exception;", "Iterator features();", "public List<Feature> process(String tag, String data);", "public List<News> query(List<float[]> waypoints);", "public void calcualteFeatureValue(Collection<Instance> instanceCollection);", "iet.distributed.telemetry.Feature getFeature(int index);", "public String getFeatVect();", "public Feature[] getFeatures() {\n Feature[] features = new Feature[rows.size()];\n for(int i=0;i<features.length;i++){\n features[i] = (Feature)rows.elementAt(i);\n }\n return features;\n }", "public void setFeatures(List<String> features) {\n this.features = features;\n }", "public List<GenPolynomial<C>> \n GB( List<GenPolynomial<C>> F ) { \n return GB(0,F);\n }", "public void addFeatures(Feature... f) {\r\n addFeatures(Arrays.asList(f));\r\n }", "private Data[] getFloats(double value, int npoints, int nattributes)\n\t{\n\t\tData[] data = new Data[npoints];\n\t\tfor (int i = 0; i < npoints; i++)\n\t\t\tdata[i] = nattributes == 1 ? new DataFloat((float) value)\n\t\t: new DataArrayOfFloats(new float[] { (float) value,\n\t\t\t\t(float) value });\n\t\t\treturn data;\n\t}", "java.lang.String getFeatures(int index);", "private List<WebServiceFeature> getFeatures(AssertionSet alternative) {\n return Collections.emptyList();\n }", "public abstract java.util.Map<java.lang.Double, java.util.List<java.lang.Integer>> pnlListMap();", "public abstract void addFeatures(Collection<Double> indices,Predicate pred, Word arg,boolean allWords);", "public void addFeatures(@Nonnull Collection<Feature> f) {\r\n features.addAll(f);\r\n }", "public List<Double> getFunction () {\n return myCoefficients;\n }", "public List<Double> getData( ) {\r\n return data;\r\n }", "org.landxml.schema.landXML11.PlanFeatureDocument.PlanFeature getPlanFeatureArray(int i);", "public List<String> getFeatures() {\n return features;\n }", "private FeatureCollection<SimpleFeatureType, SimpleFeature> findFeatures( FeatureStore<SimpleFeatureType, SimpleFeature> store, List<String> fidList ) throws SOProcessException {\n \n\n try {\n FidFilter filter = FILTER_FACTORY.createFidFilter();\n filter.addAllFids(fidList);\n \n FeatureCollection<SimpleFeatureType, SimpleFeature> features = store.getFeatures(filter);\n return features;\n \n } catch (IOException e) {\n final String msg = e.getMessage();\n LOGGER.severe(msg);\n throw new SOProcessException(msg);\n }\n }", "public java.util.List getFeature() \n {\n \tModelFacade instance = ModelFacade.getInstance(this.refOutermostPackage().refMofId());\n \tif (instance != null && \n \t\tinstance.isRepresentative(this.refMofId())&&\n \t\tinstance.hasRefObject(this.refMofId()))\n \t{ \t\n \t\tList list = instance.getFeature(this.refMofId());\n \t\tlist.addAll(super_getFeature());\n \t\t\n \t\treturn list; \t\t\n \t}\n \n \treturn super_getFeature();\n }", "public abstract float[] getasFloat(int tuple);", "Collection<Feature> getReference();", "public Iterator<SimpleFeature> getFeatures() {\n \treturn this.iterator();\n }", "public Set<String> getFeatures();", "public void addFeatures(IFeature feature);", "long getFeaturesUsed();", "public ArrayList<Float> leerMapaDesdeBaseDeDatos() {\n listaNumeros.add(2.0f);\r\n listaNumeros.add(3.0f);\r\n listaNumeros.add(4.0f);\r\n listaNumeros.add(5.0f);\r\n listaNumeros.add(1.0f);\r\n return listaNumeros;\r\n }", "private HashMap<String, double[]> readFeature(String featurePath, int currCount){\n HashMap<String, double[]> fList = new HashMap<>();\n try{\n FileReader fr = new FileReader(featurePath);\n BufferedReader br = new BufferedReader(fr);\n\n String line = br.readLine();\n while(line != null){\n\n String[] split = line.trim().split(\"\\t\");\n if (split.length < 2)\n continue;\n double[] fs = new double[split.length - 1];\n for (int i = 1; i < split.length; i ++){\n fs[i-1] = Double.valueOf(split[i]);\n }\n\n fList.put(split[0], fs);\n \n // Update ProgressBar\n SoundEffectDemo.s_progressBar.setValue(currCount);\n \t\tdouble currPercentage = ((double) currCount / ((double) s_numTrainingData * 4.0)) * 100.0;\n \t\tSoundEffectDemo.s_progressBar.setString(String.format(\"%.2f\", currPercentage) + \"%\");\n \t\tcurrCount++;\n \t\t\n line = br.readLine();\n }\n br.close();\n\n }catch (Exception e){\n e.printStackTrace();\n }\n\n return fList;\n }", "OpFList createOpFList();", "void setFeatures(Features f) throws Exception;", "void addFeatures(Features features);", "java.util.List<it.unipr.aotlab.dmat.core.generated.MatrixPieceTripletsBytesWire.Triplet> \n getValuesList();", "public void readInputFeature(ArrayList<FeatureMap> feature_maps ){\n\n\t\tif(debugPool)\n\t\t\tSystem.out.println(\" No of featureMaps in previos ConvLayer : \" + feature_maps.size());\n\n\t\t// for (FeatureMap feature_map: feature_maps){\n\n\t\t// }\n\n\t\tfor (int i = 0; i < feature_maps.size() ; i++){\n\n\t\t\tFeatureMap feature_map = feature_maps.get(i);\n\n\t\t\tDouble [][]fMap = feature_map.getFeatureMap();\n\n\t\t\tPoolMap poolMap = poolMaps.get(i);\n\n\t\t\tDouble [][] pMap = poolMap.getInputFeature();\n\n\t\t\tfor(int j = 0 ; j < fMap.length; j++){\n\n\t\t\t\tSystem.arraycopy( fMap[j],0, pMap[j], 0, fMap[j].length);\n\t\t\t}\n\t\t}\n\n\t}", "public IDataSet extractFeatures(String featureType);", "public Registro(List<Double> d) \n { \n\t this.setContenido((ArrayList<Double>) d);\n }", "public Iterable<Float> getFloats(String key);", "org.landxml.schema.landXML11.PlanFeatureDocument.PlanFeature[] getPlanFeatureArray();", "public abstract ArrayList<AprilTagDetection> getFreshDetections();", "List<EffectPointModel> mo70331d();", "public List<Vector<Double>> createFeatureVectors(List<List<RecordBean>> splittedRecordBeansList){\n\n List<Vector<Double>> featureVectorList = new ArrayList<>();\n for(int i = 0; i < splittedRecordBeansList.size(); i++){\n Vector<Double> featureVector = new Vector<>(5);\n featureVector.add(averagePacketsperRequest(splittedRecordBeansList.get(i)));\n featureVector.add(averageBytesperRequest(splittedRecordBeansList.get(i)));\n featureVector.add(getPacketEntropyDistribution(splittedRecordBeansList.get(i)));\n featureVector.add(getByteEntropyDistribution(splittedRecordBeansList.get(i)));\n featureVector.addAll((getProtocolRatios(splittedRecordBeansList.get(i))));\n featureVector.add(getLabel(splittedRecordBeansList.get(i)));\n featureVectorList.add(featureVector);\n }\n\n return featureVectorList;\n }", "public ISlideData getFeature(int index);", "public abstract Map<String,? extends Number> nodeFeatures(int n);", "public void setInstances(List<double[]> features) {\n\t\tthis.instances = features;\n\t}", "public int getFeaturesCount();", "public static <O extends Serializable> ArrayList<ERTMemoryLessTrainingPoint<O>> getMemoryLessTrainingPoints(\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tHashMap<String, ArrayList<Double>> features, \n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\tArrayList<O> labels)\n\t{\n\t\tArrayList<ERTMemoryLessTrainingPoint<O>> points = new ArrayList<ERTMemoryLessTrainingPoint<O>>();\n\t\tfor (int i = 0; i < labels.size(); i++)\n\t\t{\n\t\t\tERTMemoryLessTrainingPoint<O> newPoint = new ERTMemoryLessTrainingPoint<O>(i, features, labels);\n\t\t\tpoints.add(newPoint);\n\t\t}\n\t\treturn points;\n\t}", "public abstract ArrayList<AprilTagDetection> getDetections();", "public interface MutableFitnessMeasure\n <V extends FeatureList<? extends FeatureValue>>\n extends FitnessMeasure\n{\n //--------------------------------------------------------------------\n public void add(V predicted, V actual);\n}", "public vis.smart.webservice.ProteinFeaturesFeature[] getFeature() {\n return feature;\n }", "int getFeatureValue();", "public abstract void generateFeatureVector(Factor<Scope> f);", "@Nonnull\r\n public Set<Feature> getFeatures() {\r\n return features;\r\n }", "int getFeatureCount();", "public static String getPointsOfInterestJSON(ArrayList<ArrayList<Double>> geoList){\n Map featureCollectionObj = new LinkedHashMap();\n featureCollectionObj.put(\"type\", \"FeatureCollection\");\n\n /*\"features\": [\n { type\": \"Feature\",\n \"geometry\": {\n */\n JSONArray geoJSON = new JSONArray();\n\n /*\n \"type\": \"Feature\",\n \"geometry\": {\n \"type\": \"LineString\",\n */\n Map featureObj = new LinkedHashMap();\n featureObj.put(\"type\",\"Feature\");\n\n /*\n \"type\": \"Polygon\",\n \"coordinates\": [ [ [102.0, 0.0], [103.0, 1.0] ..\n */\n Map polygonObj = new LinkedHashMap();\n polygonObj.put(\"type\",\"Polygon\");\n\n ArrayList<ArrayList<ArrayList<Double>>> geoArrayList = new ArrayList<>();\n geoArrayList.add(geoList);\n polygonObj.put(\"coordinates\", geoArrayList);\n\n featureObj.put(\"geometry\",polygonObj);\n\n geoJSON.add(featureObj);\n\n featureCollectionObj.put(\"features\",geoJSON);\n\n String geoJSONtoString = JSONValue.toJSONString(featureCollectionObj);\n System.out.print(geoJSONtoString);\n return geoJSONtoString;\n\n }", "private void addFeatureFieldGetSet(FeatureImpl fi) {\n this.fi = fi;\n featureFieldName = getFeatureFieldName(fi);\n rangeJavaDescriptor = fi.getRangeAsJavaDescriptor();\n \n addFeatureField(); // add declares for fields\n addFeatureGetSet();\n TypeImpl range = (TypeImpl) fi.getRange();\n if (range.isArray()) {\n rangeArrayElementJavaDescriptor = fi.getRangeArrayElementAsJavaDescriptor();\n addArrayFeatureGetSet();\n }\n }", "public static void main(String[] args) {\n float[] fb=new float[9];\n fb[0]=(int)12;\n fb[1]=(byte)13;\n fb[2]=(short)8;\n fb[3]=12.021f;\n // fb[4]=23443.43d;\n// fb[4]='a';\n// for(int i=0;i<=4;i++) {\n// \t System.out.println(fb[i]);\n// }\n List<Integer> lis1=new ArrayList<>();\n List<Integer> lis2=new ArrayList<>();\n lis1.add(2);\n lis1.add(4);\n lis1.add(16);\n lis1.add(32);\n lis1.add(96);\n lis1.add(123);\n lis1.add(435);\n lis1.add(234);\n lis1.add(100);\n lis1.add(122);\n lis1.add(240);\n lis1.add(350);\n java.util.Iterator<Integer> itr= lis1.iterator();\n //while(itr.hasNext()) {\n // itr.remove();\n \t System.out.println(itr.next());\n \t System.out.println(itr.next());\n \t System.out.println(itr.next());\n \t System.out.println(itr.next());\n\n \t System.out.println(itr.next());\n \t System.out.println(itr.next());\n \t System.out.println(itr.next());\n\n \t System.out.println(lis1);\n // \n// long startTime = System.currentTimeMillis();\n// getTotalX(lis1,lis2);\n// System.out.println(\"Time taken by 2 * o(n^2) \" + (System.currentTimeMillis() - startTime) + \"ms\"); \n// \n \t\t \n\t}", "int countFeatures();", "int countFeatures();", "public WebServiceFeature[] getFeatures() {\n\t\treturn null;\n\t}", "public List<Double> getData() {\n return data;\n }", "@Override\n\tpublic List<Double> computeValues() {\n\t\treturn null;\n\t}", "private List<XmlElementNameAndContents> encodeFeatures(TOP fs, AttributesImpl attrs,\n boolean insideListNode) throws SAXException {\n List<XmlElementNameAndContents> childElements = new ArrayList<>();\n // int heapValue = cds.cas.getHeapValue(addr);\n // int[] feats = cds.tsi.ll_getAppropriateFeatures(heapValue);\n\n String attrValue;\n // boolean isSofa = false;\n // if (sofaTypeCode == heapValue)\n // {\n // // set isSofa flag to apply SofaID mapping and to store sofaNum->xmi:id mapping\n // isSofa = true;\n // }\n for (final FeatureImpl fi : fs._getTypeImpl().getFeatureImpls()) {\n\n if (cds.isFiltering) {\n // skip features that aren't in the target type system\n String fullFeatName = fi.getName();\n if (cds.filterTypeSystem_inner.getFeatureByFullName(fullFeatName) == null) {\n continue;\n }\n }\n\n final String featName = fi.getShortName();\n final int featureValueClass = fi.rangeTypeClass;\n\n switch (featureValueClass) {\n\n case LowLevelCAS.TYPE_CLASS_BYTE:\n case LowLevelCAS.TYPE_CLASS_SHORT:\n case LowLevelCAS.TYPE_CLASS_INT:\n case LowLevelCAS.TYPE_CLASS_LONG:\n case LowLevelCAS.TYPE_CLASS_FLOAT:\n case LowLevelCAS.TYPE_CLASS_DOUBLE:\n case LowLevelCAS.TYPE_CLASS_BOOLEAN:\n attrValue = fs.getFeatureValueAsString(fi);\n break;\n\n case LowLevelCAS.TYPE_CLASS_STRING:\n attrValue = fs.getFeatureValueAsString(fi);\n break;\n\n // Arrays\n case LowLevelCAS.TYPE_CLASS_INTARRAY:\n case LowLevelCAS.TYPE_CLASS_FLOATARRAY:\n case LowLevelCAS.TYPE_CLASS_BOOLEANARRAY:\n case LowLevelCAS.TYPE_CLASS_BYTEARRAY:\n case LowLevelCAS.TYPE_CLASS_SHORTARRAY:\n case LowLevelCAS.TYPE_CLASS_LONGARRAY:\n case LowLevelCAS.TYPE_CLASS_DOUBLEARRAY:\n case LowLevelCAS.TYPE_CLASS_FSARRAY:\n if (cds.isStaticMultiRef(fi)) {\n attrValue = cds.getXmiId(fs.getFeatureValue(fi));\n } else {\n attrValue = arrayToString(fs.getFeatureValue(fi), featureValueClass);\n }\n break;\n\n // special case for StringArrays, which stored values as child elements rather\n // than attributes.\n case LowLevelCAS.TYPE_CLASS_STRINGARRAY:\n StringArray stringArray = (StringArray) fs.getFeatureValue(fi);\n if (cds.isStaticMultiRef(fi)) {\n attrValue = cds.getXmiId(stringArray);\n } else if (stringArray != null && stringArray.size() == 0) {\n attrValue = \"\"; // https://issues.apache.org/jira/browse/UIMA-5558\n } else {\n stringArrayToElementList(featName, (StringArray) fs.getFeatureValue(fi),\n childElements);\n attrValue = null;\n }\n break;\n\n // Lists\n case CasSerializerSupport.TYPE_CLASS_INTLIST:\n case CasSerializerSupport.TYPE_CLASS_FLOATLIST:\n case CasSerializerSupport.TYPE_CLASS_FSLIST:\n TOP startNode = fs.getFeatureValue(fi);\n if (insideListNode || cds.isStaticMultiRef(fi)) {\n // If the feature has multipleReferencesAllowed = true OR if we're already\n // inside another list node (i.e. this is the \"tail\" feature), serialize as a normal\n // FS.\n // Otherwise, serialize as a multi-valued property.\n // if (cds.isStaticMultRef(feats[i]) ||\n // cds.embeddingNotAllowed.contains(featVal) ||\n // insideListNode) {\n\n attrValue = cds.getXmiId(startNode);\n } else {\n attrValue = listToString((CommonList) fs.getFeatureValue(fi));\n }\n break;\n\n // special case for StringLists, which stored values as child elements rather\n // than attributes.\n case CasSerializerSupport.TYPE_CLASS_STRINGLIST:\n if (insideListNode || cds.isStaticMultiRef(fi)) {\n attrValue = cds.getXmiId(fs.getFeatureValue(fi));\n } else {\n // it is not safe to use a space-separated attribute, which would\n // break for strings containing spaces. So use child elements instead.\n StringList stringList = (StringList) fs.getFeatureValue(fi);\n if (stringList == null) {\n attrValue = null;\n } else {\n if (stringList instanceof EmptyStringList) {\n attrValue = \"\";\n } else {\n List<String> listOfStrings = stringList.anyListToStringList(null, cds);\n // if (array.length > 0 && !arrayAndListFSs.put(featVal, featVal)) {\n // reportWarning(\"Warning: multiple references to a ListFS. Reference identity\n // will not be preserved.\");\n // }\n for (String string : listOfStrings) {\n childElements.add(new XmlElementNameAndContents(\n new XmlElementName(\"\", featName, featName), string));\n }\n attrValue = null;\n }\n }\n }\n break;\n\n default: // Anything that's not a primitive type, array, or list.\n attrValue = cds.getXmiId(fs.getFeatureValue(fi));\n break;\n\n } // end of switch\n\n if (attrValue != null && featName != null) {\n addAttribute(attrs, featName, attrValue, \"\");\n }\n } // end of for loop over all features\n\n // add out-of-typesystem features, if any\n if (cds.sharedData != null) {\n OotsElementData oed = cds.sharedData.getOutOfTypeSystemFeatures(fs);\n if (oed != null) {\n // attributes\n Iterator<XmlAttribute> attrIter = oed.attributes.iterator();\n while (attrIter.hasNext()) {\n XmlAttribute attr = attrIter.next();\n addAttribute(workAttrs, attr.name, attr.value);\n }\n // child elements\n childElements.addAll(oed.childElements);\n }\n }\n return childElements;\n }", "@RequestLine(\"GET /v1/users/{userId}/features\")\n @Headers({\n \"Accept: application/json\",\n })\n List<Feature> listFeaturesUsers(@Param(\"userId\") String userId);", "int getFeaturesCount();", "private void floatFLConnections(Context context,MapList FLInfoList ) throws Exception\r\n {\r\n \t Iterator FLInfoListItr = FLInfoList.iterator();\r\n \t while(FLInfoListItr.hasNext())\r\n \t {\r\n \t\t try{\r\n \t\t\t Map FLInfoMap = (Map)FLInfoListItr.next();\r\n \t\t\t \r\n \t\t\t String strNewRelId = (String)FLInfoMap.get(\"newRelId\");\r\n \t\t\t String strNewRelType1 = (String)FLInfoMap.get(\"newRelType\");\r\n\r\n \t\t\t Map mFLConnections = (Map)FLInfoMap.get(\"infoMapFLConnection\");\r\n\r\n \t\t\t String strFeatType = (String) mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_FEATURE_TYPE+\"]\");\r\n\r\n \t\t\t String strNewFeatType =(String) mFLConnections.get(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].from.attribute[\"+ATTRIBUTE_NEW_FEATURE_TYPE+\"]\");\r\n \t\t\t if(strNewFeatType==null || strNewFeatType.trim().equals(\"\"))\r\n \t\t\t\t strNewFeatType =(String) mFLConnections.get(\"to[\" + ConfigurationConstants.RELATIONSHIP_INACTIVE_FEATURE_LIST_FROM + \"].from.attribute[\"+ATTRIBUTE_NEW_FEATURE_TYPE+\"]\");\r\n\r\n \t\t\t if(ProductLineCommon.isNotNull(strNewFeatType)){\r\n \t\t\t\t strNewFeatType = PropertyUtil.getSchemaProperty(context, strNewFeatType);\r\n \t\t\t }\r\n \t\t\t else{\r\n \t\t\t\t strNewFeatType = \"\";\r\n \t\t\t }\r\n\r\n \t\t\t String strMandAtt = (String) mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_MANDATORY_FEATURE+\"]\");\r\n\r\n \t\t\t //Get the Context Product id\r\n \t\t\t String strContxtProdId = (String) mFLConnections.get(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].from.id\");\r\n \t\t\t if(strContxtProdId==null || strContxtProdId.trim().equals(\"\"))\r\n \t\t\t\t strContxtProdId = (String) mFLConnections.get(\"to[\" + ConfigurationConstants.RELATIONSHIP_INACTIVE_FEATURE_LIST_FROM + \"].from.id\");\r\n \t\t\t String strCommittedFeat = (String) mFLConnections.get(\"from[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_TO + \"].to.id\");\r\n \t\t\t \r\n \t\t\t Set FLMapKeySet = (Set) mFLConnections.keySet();\r\n \t\t\t Iterator FLMapKeySetItr = FLMapKeySet.iterator();\r\n \t\t\t while (FLMapKeySetItr.hasNext()) {\r\n \t\t\t\t String key = (String) FLMapKeySetItr.next();\r\n\r\n \t\t\t\t Object objRelIds = mFLConnections.get(key);\r\n \t\t\t\t StringList slRelIds = new StringList();\r\n\r\n \t\t\t\t if (objRelIds instanceof StringList) {\r\n \t\t\t\t\t slRelIds = (StringList) mFLConnections.get(key);\r\n \t\t\t\t } else if (objRelIds instanceof String) {\r\n \t\t\t\t\t slRelIds.addElement((String) mFLConnections.get(key));\r\n \t\t\t\t }\r\n\r\n \t\t\t\t Iterator relIdsItr = slRelIds.iterator();\r\n \t\t\t\t while (relIdsItr.hasNext()){\r\n \t\t\t\t\t String relId = (String) relIdsItr.next();\r\n\r\n \t\t\t\t\t /*In case of \"Manufacturing Features,Marketing Features\" we are not going to add PFL in 2012x\r\n \t\t\t\t\t * which we used to have in 2012.\r\n \t\t\t\t\t */\r\n \t\t\t\t\t if(key!=null && key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_PRODUCT_FEATURE_LIST + \"].id\")){\r\n\r\n \t\t\t\t\t\t if(strFeatType!=null\r\n \t\t\t\t\t\t\t && !strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MANUFACTURING)\r\n \t\t\t\t\t\t\t && !strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MARKETING)\r\n \t\t\t\t\t\t\t //&& !strNewFeatType.equalsIgnoreCase(ConfigurationConstants.TYPE_CONFIGURATION_FEATURE)\r\n \t\t\t\t\t\t\t //&& !strNewFeatType.equalsIgnoreCase(ConfigurationConstants.TYPE_CONFIGURATION_OPTION)\r\n \t\t\t\t\t\t\t && !mxType.isOfParentType(context, strNewFeatType, ConfigurationConstants.TYPE_CONFIGURATION_FEATURES)\r\n \t\t\t\t\t\t\t && !strNewFeatType.equalsIgnoreCase(\"emxR212~Configuration Feature\")\r\n \t\t\t\t\t\t\t && (strNewRelType1!=null && !strNewRelType1.equalsIgnoreCase(ConfigurationConstants.RELATIONSHIP_CONFIGURATION_OPTIONS))\r\n \t\t\t\t\t\t\t && (strNewRelType1!=null && !strNewRelType1.equalsIgnoreCase(ConfigurationConstants.RELATIONSHIP_CONFIGURATION_FEATURES))\r\n \t\t\t\t\t\t\t ){\r\n\r\n \t\t\t\t\t\t\t DomainRelationship domRel = new DomainRelationship(relId);\r\n \t\t\t\t\t\t //Get the attributes on Relationship\r\n \t\t\t\t\t\t Map attributeMap = new HashMap();\r\n \t\t\t\t\t\t attributeMap = domRel.getAttributeMap(context,true);\r\n\r\n\t \t\t\t\t\t\t //Check for the value of \"Feature Allocation Type\" attribute value\r\n\t \t\t\t\t\t\t\t String strFATVal = (String)attributeMap.get(ConfigurationConstants.ATTRIBUTE_FEATURE_ALLOCATION_TYPE);\r\n\t \t\t\t\t\t\t\t if(ProductLineCommon.isNotNull(strFATVal)\r\n\t \t\t\t\t\t\t\t\t && strFATVal.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MANDATORY)){\r\n\r\n\t \t\t\t\t\t\t\t\t attributeMap.put(ConfigurationConstants.ATTRIBUTE_FEATURE_ALLOCATION_TYPE,\r\n\t \t\t\t\t\t\t\t\t\t\t ConfigurationConstants.RANGE_VALUE_REQUIRED);\r\n\t \t\t\t\t\t\t\t\t mqlLogRequiredInformationWriter(\"Value of 'Feature Allocation Type' attribute for Rel id : \" + relId\r\n\t \t\t\t\t\t\t\t\t\t\t + \"\\n\"\r\n\t \t\t\t\t\t\t\t\t\t\t + \"changed from 'Mandatory' to 'Required'.\"\r\n\t \t\t\t\t\t\t\t\t\t\t + \"\\n\\n\");\r\n\t \t\t\t\t\t\t\t }else if(!ProductLineCommon.isNotNull(strFATVal)\r\n\t \t\t\t\t\t\t\t\t\t || \" \".equalsIgnoreCase(strFATVal)){\r\n\r\n\t \t\t\t\t\t\t\t\t mqlLogRequiredInformationWriter(\"Value of 'Feature Allocation Type' attribute for Rel id : \" + relId\r\n\t\t\t\t + \"\\n\"\r\n\t\t\t\t + \"is blank.\"\r\n\t\t\t\t + \"\\n\\n\");\r\n\t \t\t\t\t\t\t\t\t attributeMap.put(ConfigurationConstants.ATTRIBUTE_FEATURE_ALLOCATION_TYPE,\r\n\t\t\t\t\t\t\t\t\t\t ConfigurationConstants.RANGE_VALUE_OPTIONAL);\r\n\t \t\t\t\t\t\t\t\t mqlLogRequiredInformationWriter(\"Value of 'Feature Allocation Type' attribute for Rel id : \" + relId\r\n\t\t\t\t + \"\\n\"\r\n\t\t\t\t + \"changed from blank to 'Optional'.\"\r\n\t\t\t\t + \"\\n\\n\");\r\n\r\n\t \t\t\t\t\t\t\t }\r\n\t \t\t\t\t\t\t\t replaceIntermediateObjectWithRel(context, relId, strNewRelId, \"to\",attributeMap);\r\n \t\t\t\t\t\t }\r\n\r\n \t\t\t\t\t }else if(key!=null && key.equalsIgnoreCase(\"from.from[\" + ConfigurationConstants.RELATIONSHIP_RESOURCE_USAGE + \"].id\")){\r\n\r\n \t\t\t\t\t\t DomainRelationship domRel = new DomainRelationship(relId);\r\n\t\t\t\t\t\t //Get the attributes on Relationship\r\n\t\t\t\t\t\t Map attributeMap = new HashMap();\r\n\t\t\t\t\t\t attributeMap = domRel.getAttributeMap(context,true);\r\n \t\t\t\t\t\t replaceIntermediateObjectWithRel(context, relId, strNewRelId, \"from\",attributeMap);\r\n\r\n \t\t\t\t\t }else if(key!=null && key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_COMMITED_ITEM + \"].id\")) {\r\n\r\n\r\n \t\t\t\t\t\t String ifFLFromRelExits =(String) mFLConnections.get(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].id\");\r\n\t\t\t\t\t\t \t\t\t\t\t\t String strNewRelType=\"\";\r\n\t\t\t\t\t\t \t\t\t\t\t\t if(ifFLFromRelExits!=null && ifFLFromRelExits.length()!=0){\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t //Depending upon the \"Feature Type\" we are going to change the relationship \"Committed Item\"\r\n\t\t\t\t\t\t \t\t\t\t\t\t if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_TECHNICAL)){\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_COMMITTED_LOGICAL_FEATURES;\r\n\t\t\t\t\t\t \t\t\t\t\t\t }else if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MARKETING)){\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t /*In R211, Mandatory CF where getting added as Committed Features.\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t In R212 they should be added as \"Mandatory Configuration Features\".*/\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t if(strMandAtt!=null && strMandAtt.equalsIgnoreCase(\"Yes\")){\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES;\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t }else{\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_COMMITTED_CONFIGURATION_FEATURES;\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t }\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t /*if(strMandAtt!=null && !strMandAtt.equalsIgnoreCase(\"Yes\")){\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\tstrNewRelType = ConfigurationConstants.RELATIONSHIP_COMMITTED_CONFIGURATION_FEATURES;\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t }*/\r\n\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }else if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MANUFACTURING)){\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_COMMITTED_MANUFACTURING_FEATURES;\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }else if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_NONE)){\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_COMMITTED_CONFIGURATION_FEATURES;\r\n\t\t\t\t\t\t \t\t\t\t\t\t }\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }else{\r\n\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_MARKETING)\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t || strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_NONE))\r\n\t\t\t\t\t\t \t\t\t\t\t\t {\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES;\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }/*else if(strFeatType!=null && strFeatType.equalsIgnoreCase(ConfigurationConstants.RANGE_VALUE_NONE)){\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t strNewRelType = ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES;\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }*/\r\n\t\t\t\t\t\t \t\t\t\t\t\t }\r\n\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t if(ProductLineCommon.isNotNull(strNewRelType)){\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t//Change the \"To Side\" of \"Committed Item\" relationship to Committed CF/LF/MF\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t //String strMqlCommand = \"modify connection \"\t+ relId + \" to \" + strCommittedFeat;\r\n\t\t\t\t\t\t \t\t\t\t\t\t\t String strMqlCommand = \"modify connection $1 to $2\";\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t MqlUtil.mqlCommand(context, strMqlCommand,true,relId,strCommittedFeat);\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t //\"Committed Item\" to \"Committed CF/LF/MF\" relationship\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t DomainRelationship.setType(context, relId, strNewRelType);\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t HashMap mapRelAttributes = new HashMap();\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t if(strNewRelType!=null && strNewRelType.equalsIgnoreCase(ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES)){\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_SEQUENCE_ORDER,\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t (String)mFLConnections.get(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].attribute[\"+ConfigurationConstants.ATTRIBUTE_SEQUENCE_ORDER+\"]\"));\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_DEFAULT_SELECTION,\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t (String)mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_DEFAULT_SELECTION+\"]\"));\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_LIST_PRICE,\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t (String)mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_LIST_PRICE+\"]\"));\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_MAXIMUM_QUANTITY,\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t (String)mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_MAXIMUM_QUANTITY+\"]\"));\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_MINIMUM_QUANTITY,\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t (String)mFLConnections.get(\"attribute[\"+ConfigurationConstants.ATTRIBUTE_MINIMUM_QUANTITY+\"]\"));\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_CONFIGURATION_TYPE,ConfigurationConstants.RANGE_VALUE_SYSTEM);\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t //Set \"Inherited\" attribute set to to True ,CF is inherited from PL\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_INHERITED,ConfigurationConstants.RANGE_VALUE_TRUE);\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mapRelAttributes.put(ConfigurationConstants.ATTRIBUTE_ROLLED_UP,ConfigurationConstants.RANGE_VALUE_FALSE);\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t DomainRelationship domRel1 = new DomainRelationship(relId);\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t mqlLogRequiredInformationWriter(\"Rel id :: \"+ relId +\"\\n\");\r\n\t\t\t\t\t\t\t \t\t\t\t\t mqlLogRequiredInformationWriter(\"Attribute value Map set for this Rel id :: \"+ mapRelAttributes +\"\\n\\n\");\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t domRel1.setAttributeValues(context, mapRelAttributes);\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t }\r\n\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t //Connect new Rel with Contxt Prod Id with new Relationship \"Committed Context\"\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t if(ProductLineCommon.isNotNull(strContxtProdId)){\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t\t String strRel = ConfigurationConstants.RELATIONSHIP_COMMITTED_CONTEXT;\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t RelationshipType strRelType = new RelationshipType(strRel);\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t ProductLineCommon PL = new ProductLineCommon(relId);\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t PL.connectObject(context,\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t\t strRelType,\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t\t strContxtProdId,\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t\t false);\r\n\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t mqlLogRequiredInformationWriter(\"Connection between ::\"\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t \t\t\t\t\t\t + relId\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t \t\t\t\t\t\t + strRelType\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t\t\t \t\t\t\t\t\t +\tstrContxtProdId\r\n\t\t\t\t\t\t\t\t \t\t\t\t\t\t \t\t\t\t\t\t\t\t\t);\r\n\t\t\t\t\t\t\t \t\t\t\t\t\t }\r\n\r\n\t\t\t\t\t\t \t\t\t\t\t\t }\r\n \t\t\t\t\t }\r\n \t\t\t\t\t else if(key.startsWith(\"to\")\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].type\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].from.id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\" + ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM + \"].from.type\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.attribute[\"+ATTRIBUTE_NEW_FEATURE_TYPE+\"]\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].attribute[\"+ATTRIBUTE_SEQUENCE_ORDER+\"]\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_INACTIVE_FEATURE_LIST_FROM+\"].from.id\"))\r\n\t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_INACTIVE_FEATURE_LIST_FROM+\"].id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_INACTIVE_FEATURE_LIST_FROM+\"].from.type\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_TO+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].from.id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].from.id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].attribute[\"+ConfigurationConstants.ATTRIBUTE_KEY_IN_VALUE+\"]\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_TO+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_CONFIGURATION_FEATURES+\"].tomid[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_CONFIGURATION_FEATURES+\"].tomid[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].from.id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES+\"].tomid[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].from.id\"))\r\n \t\t\t\t\t\t\t && !(key.equalsIgnoreCase(\"to[\"+ConfigurationConstants.RELATIONSHIP_FEATURE_LIST_FROM+\"].from.to[\"+ConfigurationConstants.RELATIONSHIP_MANDATORY_CONFIGURATION_FEATURES+\"].tomid[\"+ConfigurationConstants.RELATIONSHIP_SELECTED_OPTIONS+\"].id\")))\r\n \t\t\t\t\t\t\t {\r\n\t\t \t\t\t\t\t\t DomainRelationship domRel = new DomainRelationship(relId);\r\n\t\t\t\t\t\t\t\t //Get the attributes on Relationship\r\n\t\t\t\t\t\t\t\t Map attributeMap = new HashMap();\r\n\t\t\t\t\t\t\t\t attributeMap = domRel.getAttributeMap(context,true);\r\n \t\t\t\t\t\t replaceIntermediateObjectWithRel(context, relId, strNewRelId,\"to\",attributeMap);\r\n\t \t\t\t\t\t }\r\n\t \t\t\t\t }\r\n \t\t\t }\r\n \t\t }catch(Exception e)\r\n \t\t {\r\n \t\t\t e.printStackTrace();\r\n \t\t\t throw new FrameworkException(e.getMessage() + \"\\n\");\r\n \t\t }\r\n \t }\r\n }", "public ArrayList<Flight> legs()\n {\n \t return this.mLegs;\n }" ]
[ "0.6819819", "0.6808422", "0.6758721", "0.6672154", "0.6516264", "0.6516264", "0.6504454", "0.6302709", "0.62943465", "0.6269238", "0.62641275", "0.62443864", "0.6164228", "0.6102517", "0.5989585", "0.58834493", "0.58834493", "0.5854324", "0.5831782", "0.5827027", "0.5795619", "0.57870454", "0.5753245", "0.5712143", "0.5705297", "0.56960285", "0.56960285", "0.5654557", "0.561585", "0.5605477", "0.55914795", "0.5582604", "0.5582547", "0.557794", "0.5563471", "0.5561164", "0.5552598", "0.5551756", "0.5503162", "0.5501218", "0.5480516", "0.54752773", "0.54685897", "0.5435848", "0.5433557", "0.5414251", "0.5380993", "0.53750676", "0.53633726", "0.53531504", "0.53374153", "0.5333079", "0.53326213", "0.53254664", "0.5318577", "0.5318168", "0.5318", "0.5312199", "0.5296084", "0.52885646", "0.52860427", "0.5281704", "0.5275914", "0.52712667", "0.52695614", "0.52590734", "0.5240016", "0.5237358", "0.52320844", "0.52309096", "0.52291054", "0.52254766", "0.52178025", "0.5217662", "0.52096224", "0.5202114", "0.51985174", "0.5198507", "0.51895964", "0.51817644", "0.51754975", "0.5155611", "0.51465833", "0.51457983", "0.5142605", "0.5142495", "0.513425", "0.512585", "0.5111197", "0.5103057", "0.5096846", "0.5088435", "0.5088435", "0.50873965", "0.5075522", "0.5075207", "0.5073556", "0.50628626", "0.5060921", "0.5054023", "0.50517356" ]
0.0
-1
jenia: n = 0 default in set_heldout
public void set_heldout(final int h) { set_heldout(h, 0); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void set_heldout(final int h, final int n) {\n _nheldout = h;\n _early_stopping_n = n;\n }", "protected void pktsOut(int n) {}", "public void setNumErode(int n) {\r\n itersErode = n;\r\n }", "@Override\n\tpublic int sount() {\n\t\treturn 0;\n\t}", "public abstract int finalN();", "public VipInfoPrepaid(int n) {\r\n\t\tvalue = n;\r\n\t\tinitialize();\r\n\t}", "public void setN(boolean n) {\n\tthis.n = n;\n }", "public void setLastCount(double n)\n {\n\n this.lastCount = n;\n }", "@Override\n public int retroceder() {\n return 0;\n }", "protected void txPut(int n) {}", "public void SetNMissing(int n_missing);", "@Override\r\npublic int checkout(int n) {\n\treturn super.checkout(n);\r\n}", "public void n() {\n this.f80658c.a(new f() {\n public void a(Object obj, boolean z) {\n p unused = m.this.f80658c = (p) obj;\n }\n }, \"__ag_of\");\n }", "public abstract int getUpkeep();", "public final void setN(final int koko) {\r\n this.n = koko;\r\n }", "public void setNumDeparting() {\n if (isStopped() && !embarkingPassengersSet){\n \tRandom rand = new Random();\n \tint n = rand.nextInt(this.numPassengers+1);\n \tif (this.numPassengers - n <= 0) {\n \t\tthis.numPassengers = 0;\n n = this.numPassengers;\n \t} else {\n this.numPassengers = this.numPassengers - n;\n }\n trkMdl.passengersUnboarded(trainID, n);\n }\n \t//return 0;\n }", "public void setSteak(double countNo) {\n steak = countNo;\r\n }", "public void setNulled(final boolean nulled) {\n \t\tthis.nulled = nulled;\n \t}", "public abstract int preN();", "public static void passoutNum(int n){\n\t\tpassoutNum(0,n);\n\t}", "public void setTrials(int n){\n\t\tsuper.setTrials(1);\n\t}", "public void planted(){\r\n\t\tenable = false; \r\n\t\tcount = 0; \r\n\t}", "public void setKoernerImMaul(int n)\n {\n koernerImMaul=n;\n }", "@Override\n\tpublic void setEnemyCount(int n) {\n\t\t\n\t}", "int getN();", "public Object setInitialHoldings()\r\n/* */ {\r\n\t\t\t\tlogger.info (count++ + \" About to setInitialHoldings : \" + \"Agent\");\r\n/* 98 */ \tthis.profit = 0.0D;\r\n/* 99 */ \tthis.wealth = 0.0D;\r\n/* 100 */ \tthis.cash = this.initialcash;\r\n/* 101 */ \tthis.position = 0.0D;\r\n/* */ \r\n/* 103 */ return this;\r\n/* */ }", "@Override\n\tpublic int getAllotNum() {\n\t\treturn 0;\n\t}", "public void truncate(int n) {\n if (n >= ON) return;\n compress();\n for (int i = n; i < OLast; i++) O[i] = null;\n OLast = ON = n;\n }", "public int n(){\n return n;\n }", "void setUnused(){\n assert this.used == true;\n\n //let the parent pointer remain\n this.hf = 0;\n this.used = false;\n\n }", "public void setNoBooked(int noBooked) {\n\n\t\tthis.noBooked = noBooked;\n\t}", "public void setValue(int n) {\n\t\t\tthis.value = n;\n\t}", "public void setMem(int taille_tache, int n) {\r\n if (n == 1)\r\n this.memoire -= taille_tache; // lors du placement de la tache\r\n\r\n else this.memoire += taille_tache;// lors de la fin de la tache, liberer l'espace memoire\r\n }", "@Override\n\tpublic int vanish() {\n\t\treturn 1;\n\t}", "final int getAndClearStealCount() {\n int sc = stealCount;\n stealCount = 0;\n return sc;\n }", "public synchronized void v() {\n if (value == maxvalue)\n // NOP\n return;\n ++value;\n notify(); \n //!! L’ordine di risveglio e’ arbitrario\n }", "public boolean setCurrentAccessibleValue(Number n) {\n return false;\n }", "public void aendereWert (int value) {\n\t\tvalue = 0 ;\n\t}", "@Override\n public void bankrupt() {\n this.mortgaged = false;\n }", "public Builder setN(int value) {\n \n n_ = value;\n onChanged();\n return this;\n }", "@Override\n\tprotected void unLockNbr() {\n\t\t\n\t}", "public void setPrevCount(double n)\n {\n\n this.prevCount = n;\n }", "public void setOneNewWanted () {\r\n numWanted ++;\r\n }", "public DoubleValue(int n) {\n\t\ttimesToWrite = n;\n\t}", "public int getN() {\n return n;\n }", "public void resetOccupied(){\n \t\toccupiedSeconds = 0;\n \t}", "public int getNotaFinal()\r\n {\n return 4;\r\n }", "public int getNotaFinal()\r\n {\n return 4;\r\n }", "public void mo12202n() {\n this.f10959n = -1;\n }", "public void setNetworth(int value);", "public void stworzSiec(int n) {\n\t\tneurony = new ArrayList<Neuron>();\n\t\tfor (int i = 0; i < n; i++)\n\t\t\tneurony.add(new Neuron(Ustawienia.TOTAL));\n\t}", "public void setSlotCount(int n) {\n mController.setSlotCount(n);\n }", "public void defaultUpdateCount(AcProperty e)\n {\n }", "public Builder clearN() {\n \n n_ = 0;\n onChanged();\n return this;\n }", "@Override\r\n\tpublic int runn(int k) {\n\t\treturn 0;\r\n\t}", "public abstract int getCntPrepaid();", "public void stateResetSuppression() {\n HashGroupifyEntry entry = hashTableFirstEntry;\n while (entry != null) {\n entry.isNotOutlier = true;\n entry = entry.nextOrdered;\n }\n this.currentNumOutliers = 0;\n }", "public void fillDaftar(MakhlukHidup n);", "public void set_AllSpreadIndexToZero(){\r\n\tGRASS=0; \r\n\tTIMBER=0;\r\n}", "public int emptyPit() {\r\n\t\t\r\n\t\tint temp = stones;\r\n\t\tstones = 0;\r\n\t\treturn temp;\r\n\t\t\r\n\t}", "Pinochle(){\n createDeck();\n createDeck();\n this.originalSizeOfDeck = this.deckOfCards.size();\n }", "public long getN() {\n return n;\n }", "public void setInversiones(int n){\r\n\t\tinversiones = n;\r\n\t}", "public int getN() {\r\n\t\treturn n;\r\n\t}", "@Override\n public Integer reduceInit() { return 0; }", "@Override\n public void cantidad_Defensa(){\n defensa=2+nivel+aumentoD;\n }", "public void setUpdateOften(int i){\n countNum = i;\n }", "synchronized void put(int n) { \r\n\tif(valueSet) \r\n\ttry { \r\n\twait(); \r\n\t} catch(InterruptedException e) { \r\n\tSystem.out.println(\"InterruptedException caught\"); \r\n\t} \r\n\tthis.n = n; \r\n\tvalueSet = true; \r\n //imprimo mensaje\r\n\t System.out.println(\"El hilo1 produce el numero:\"+n);\r\n\tnotify(); \r\n\t}", "@Override\n\tpublic int update() {\n\t\treturn 0;\n\t}", "public void zero();", "private void lastN(int n) {\n int len = this.getlength();\n if (n > len) {\n System.out.printf(\"too short to have last %d's\\n\", n);\n } else {\n Node slow = this;\n Node fast = this;\n for (int i = n; i > 0; i--) {\n fast = fast.nextNode;\n }\n while (fast != null) {\n slow = slow.nextNode;\n fast = fast.nextNode;\n }\n System.out.printf(\"last %d element is: %d\\n\", n, slow.value);\n }\n }", "void decUsage() {\n incUsage(-1);\n }", "protected byte[] getMeasuredAmountOfWaterRemainingInTank() {return null;}", "@Override\r\n\tprotected Integer zero() {\n\t\treturn 0;\r\n\t}", "private int cap(long n) {\n\t\t\treturn (int) Math.min(RandomAccessDataFile.this.length - this.position, n);\n\t\t}", "private void FenwickTree(int n) {\n // Store the actual values in tree[] using update()\n for(int i = 0; i < N; i++)\n updateBIT(down_tree, Max_dis, site_distance[i], raw_tree[site_distance[i]]);\n }", "@Override\r\n\tpublic double alapterulet() {\n\t\treturn 0;\r\n\t}", "public void grow(int n) {\r\n\t\t// implementation not shown\r\n\t}", "static int noValueSize() {\r\n return itemSize(false) * 2;\r\n }", "public void setCountToZero() {\r\n \r\n // set count to 0\r\n count = 0;\r\n }", "public void ferdig(){\n antallTelegrafister--;\n }", "public void setUnsoldTickets(int ticketsWanted) \n {\n this.unsoldTickets = this.unsoldTickets - ticketsWanted;\n }", "static WireloopReward freeSteps() {\n return (s, a, n) -> RealScalar.ZERO;\n }", "void unsetAmount();", "public void setNilLimit()\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n org.apache.xmlbeans.XmlNonNegativeInteger target = null;\r\n target = (org.apache.xmlbeans.XmlNonNegativeInteger)get_store().find_element_user(LIMIT$6, 0);\r\n if (target == null)\r\n {\r\n target = (org.apache.xmlbeans.XmlNonNegativeInteger)get_store().add_element_user(LIMIT$6);\r\n }\r\n target.setNil();\r\n }\r\n }", "@Override\n\tpublic int mettreAJour() {\n\t\treturn 0;\n\t}", "void noNewLoans();", "public double wrapper(double n) {\n return -1 + (n + 1) % 2;\n }", "@Override\n protected long advanceH(final long k) {\n return 5 * k - 2;\n }", "public int getDefilade();", "@Override\r\n\tpublic void unsetGiveValue() {\n\t\t\r\n\t}", "public int getN() {\n\t\treturn n;\n\t}", "private int aleatorizarNaipe() {\n\t\tint aux;\n\t\taux = r.getIntRand(4);\n\t\treturn aux;\n\t}", "static int maxLoot(int hval[], int n)\n {\n if (n == 0) return 0;\n if (n == 1) return hval[0];\n if (n == 2) return Math.max(hval[0], hval[1]);\n // dp[i] represent the maximum value stolen so far after reaching house i.\n int[] dp = new int[n];\n // Initialize the dp[0] and dp[1]\n dp[0] = hval[0];\n dp[1] = Math.max(hval[0], hval[1]);\n // Fill remaining positions\n for (int i = 2; i<n; i++)\n dp[i] = Math.max(hval[i]+dp[i-2], dp[i-1]);\n return dp[n-1];\n }", "public void reset(){\n value = 0;\n }", "public abstract int selfExplodingKittenDrawn();", "public int getN() {\n return n_;\n }", "abstract void assignZero();", "void unsetMaximum();", "private void nullstillFordeling(){\n int i = indeks;\n politi = -1;\n mafiaer = -1;\n venner = -1;\n mafia.nullstillSpesialister();\n spillere.tømTommeRoller();\n for (indeks = 0; roller[indeks] == null; indeks++) ;\n fordeling = null;\n }" ]
[ "0.7023492", "0.6240253", "0.59860396", "0.5926743", "0.5829261", "0.58106387", "0.57038975", "0.5687484", "0.5643669", "0.5633632", "0.5612083", "0.55939823", "0.55935746", "0.5593554", "0.5551447", "0.5540152", "0.5507381", "0.55067134", "0.55060816", "0.5502869", "0.5494781", "0.5482856", "0.54737484", "0.5473268", "0.5460957", "0.5454464", "0.54499924", "0.5434542", "0.5432055", "0.5431113", "0.5425361", "0.541989", "0.54180247", "0.5377148", "0.5361232", "0.53588724", "0.5355685", "0.53540796", "0.5350281", "0.53413117", "0.5329646", "0.5321708", "0.5319186", "0.5318768", "0.5316566", "0.5307799", "0.5299996", "0.5299996", "0.5299077", "0.5289843", "0.52690464", "0.5267975", "0.52557874", "0.52547157", "0.52445483", "0.524108", "0.5239531", "0.5210333", "0.5197067", "0.519481", "0.5189391", "0.51856947", "0.5172743", "0.51535475", "0.5152641", "0.51447004", "0.51413745", "0.5140167", "0.51392853", "0.5133046", "0.5131514", "0.5125003", "0.51202464", "0.51202047", "0.5117577", "0.51169837", "0.51144874", "0.51052934", "0.510399", "0.51024216", "0.5099085", "0.5095454", "0.50933826", "0.5091323", "0.5088814", "0.50870734", "0.50834703", "0.5081492", "0.5080845", "0.5080806", "0.5072827", "0.5072792", "0.5071454", "0.50681126", "0.5059913", "0.50583905", "0.5056829", "0.50551087", "0.5050439", "0.5047723" ]
0.65327764
1
reference probability distribution jenia, converted to Comparator
final boolean operator_less(final Sample x) { for (int i = 0; i < positive_features.size(); i++) { if (i >= x.positive_features.size()) return false; int v0 = positive_features.get(i); int v1 = x.positive_features.get(i); if (v0 < v1) return true; if (v0 > v1) return false; } return false; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Comparator<Integer> comparator() {\n return new Comparator<Integer>() {\n @Override\n public int compare(Integer o1, Integer o2) {\n Http2PriorityNode n1 = nodesByID.get(o1);\n Http2PriorityNode n2 = nodesByID.get(o2);\n if(n1 == null && n2 == null) {\n return 0;\n }\n if(n1 == null) {\n return -1;\n }\n if(n2 == null) {\n return 1;\n }\n //do the comparison\n //this is kinda crap, but I can't really think of any better way to handle this\n\n double d1 = createWeightingProportion(n1);\n double d2 = createWeightingProportion(n2);\n return Double.compare(d1, d2);\n }\n };\n }", "@Override\n\t\tpublic int compare(S o1, S o2) {\n\t\t\tif (getProb(o1) > getProb(o2))\n\t\t\t\treturn -1;\n\t\t\tif (getProb(o1) < getProb(o2))\n\t\t\t\treturn 1;\n\t\t\treturn Double.compare(o1.hashCode(), o2.hashCode());\n\t\t}", "public int compareTo(DerivationElement o) {\n\t\treturn (this.logProb>o.logProb)? -1 : (this.logProb==o.logProb)? 0 : 1; \n\t }", "private static Comparator<Person> comparator(CrudFilter filter) {\n return filter.getSortOrders().entrySet().stream()\n .map(sortClause -> {\n try {\n Comparator<Person> comparator\n = Comparator.comparing(person ->\n (Comparable) valueOf(sortClause.getKey(), person));\n\n if (sortClause.getValue() == SortDirection.DESCENDING) {\n comparator = comparator.reversed();\n }\n\n return comparator;\n } catch (Exception ex) {\n return (Comparator<Person>) (o1, o2) -> 0;\n }\n })\n .reduce(Comparator::thenComparing)\n .orElse((o1, o2) -> 0);\n }", "@Override\r\n\t//按权重大小排序\r\n\tpublic int compareTo(Domain o) {\n\t\treturn (o.weight-this.weight);\r\n\t}", "public int compare(Key<Double, Double> a, Key<Double, Double> b){\n\t\t\tif (a.getFirst() < b.getFirst()){\n\t\t\t\treturn -1;\n\t\t\t} else if (a.getFirst() == b.getFirst()){\n\t\t\t\treturn 0;\n\t\t\t} else {\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t}", "@Override\n public int compare(Pair<Channel, Double> lhs, Pair<Channel, Double> rhs) {\n return rhs.second.compareTo(lhs.second);\n }", "public void sortCompetitors(){\n\t\t}", "@Override\n\t\t public int compare(PathObject lhs, PathObject rhs) {\n\t\t return Double.compare(lhs.getClassProbability(), rhs.getClassProbability()); // Use double compare to safely handle NaN and Infinity\n\t\t }", "@Override\n\t\t public int compare(PathObject lhs, PathObject rhs) {\n\t\t return Double.compare(lhs.getClassProbability(), rhs.getClassProbability()); // Use double compare to safely handle NaN and Infinity\n\t\t }", "private SimplexComparator() {}", "public Comparator<? super P> comparator();", "private Comparator<Node> getComparator() {\n class QueueCompare implements Comparator<Node> {\n @Override\n public int compare(Node o1, Node o2) {\n if (o1.manPrior > o2.manPrior) return 1;\n else if (o1.manPrior < o2.manPrior) return -1;\n else if (o1.hamPrior > o2.hamPrior) return 1;\n else if (o1.hamPrior < o2.hamPrior) return -1;\n else if (o1.manPrior - o1.movesToBoard > o2.manPrior - o2.movesToBoard) return 1;\n else if (o1.manPrior - o1.movesToBoard < o2.manPrior - o2.movesToBoard) return -1;\n else if (o1.hamPrior - o1.movesToBoard > o2.hamPrior - o2.movesToBoard) return 1;\n else if (o1.hamPrior - o1.movesToBoard < o2.hamPrior - o2.movesToBoard) return -1;\n return 1;\n }\n }\n return new QueueCompare();\n }", "@Override\n\tpublic int compare(Person p1, Person p2) { //because this class implements Comparator \n\t\treturn p1.id-p2.id;\n\t}", "public int compare(Person a, Person b){\n int aWeight = (int)a.getWeight();\n int bWeight = (int)b.getWeight();\n return aWeight - bWeight;\n }", "@Test\n public void compareFunctionalBigger() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p1, p2);\n \n assertEquals(-1, a);\n\n }", "private double estimateCategoricalPropertyProb(List<TemporalElementStats> relevantStats1, String property1,\n Comparator comp,\n List<TemporalElementStats> relevantStats2,\n String property2) {\n long count1 = relevantStats1.stream()\n .map(TemporalElementStats::getElementCount)\n .reduce(0L, Long::sum);\n long count2 = relevantStats2.stream()\n .map(TemporalElementStats::getElementCount)\n .reduce(0L, Long::sum);\n long totalCount = count1 * count2;\n\n\n double outerSum = 0.;\n for (TemporalElementStats s1 : relevantStats1) {\n double innerSum = 0.;\n for (TemporalElementStats s2 : relevantStats2) {\n double prob = estimateCategoricalPropertyProb(s1, property1, comp, s2, property2);\n double weight = ((double) s1.getElementCount() * s2.getElementCount()) /\n totalCount;\n innerSum += prob * weight;\n }\n outerSum += innerSum;\n }\n return outerSum;\n }", "@Override\n\tpublic int compare(Person p1, Person p2) {\n\t\tif(p1.getWeight() >p2.getWeight()){\n\t\n\t\treturn 1;\n\t\t}\n\t\telse if(p1.getWeight()==p2.getWeight()){\n\t\t\tif(p1.getHeight() >p2.getHeight()){\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t}\n\t\treturn -1;\n\t}", "@Override\r\n\t\t\tpublic int compare(Entry<Integer, Double> o1, Entry<Integer, Double> o2) {\n\t\t\t\tif ((o1.getValue()-o2.getValue())>0) {\r\n\t\t\t\t\t\r\n\t\t\t\t\treturn 1;\r\n\t\t\t\t} else if ((o1.getValue()-o2.getValue())<0) {\r\n\t\t\t\t\treturn -1;\r\n\t\t\t\t} else {\r\n\t\t\t\t\treturn 0;\r\n\t\t\t\t}\r\n\t\t\t}", "@Override\n\t\t\tpublic int compare(Entry<Integer, Double> o1,\n\t\t\t\t\tEntry<Integer, Double> o2) {\n\t\t\t\tDouble v2 = o2.getValue();\n\t\t\t\tDouble v1 = o1.getValue();\n\t\t\t\treturn v2.compareTo(v1);\n\t\t\t}", "@Override\r\n public int compare(Pair<Integer, Double> o1, Pair<Integer, Double> o2) {\r\n return o2.getValue().compareTo(o1.getValue());\r\n }", "@Override\r\n\t\t\tpublic int compare(PrimsPair o1, PrimsPair o2) {\n\t\t\t\treturn o2.csf - o1.csf;\r\n\t\t\t}", "public Comparator<Estado> getCompHeuristicaMasProf() {\r\n\t\tcomp = new Comparator<Estado>() {\r\n\t\t\t@Override\r\n\t\t\tpublic int compare(Estado e1, Estado e2) {\r\n\t\t\t\tInteger es1 = e1.getDistanciaManhattan() + e1.getProf();\r\n\t\t\t\tInteger es2 = e2.getDistanciaManhattan() + e2.getProf();\r\n\t\t\t\tif (es1 == es2)\r\n\t\t\t\t\treturn new Integer(e1.getProf().compareTo(e2.getProf())); // En caso de empate comparo por profundidad\r\n\t\t\t\treturn new Integer(es1.compareTo(es2));\r\n\t\t\t}\r\n\t\t};\r\n\t\treturn comp;\r\n\t}", "public Artikel[] getSorted(BiPredicate<Artikel, Artikel> biPredicate){\n Artikel [] liste = new Artikel[key];\n int i = 0;\n for (Map.Entry<Integer, Artikel> integerArtikelEntry : lager.entrySet()) {\n liste[i] = integerArtikelEntry.getValue();\n i++;\n }\n\n //BubbleSort\n boolean sorted = false;\n Artikel temp;\n while (!sorted){\n sorted = true;\n for (i = 0; i < liste.length - 1; i++){\n if(biPredicate.test(liste[i], liste[i+1])){\n temp = liste[i];\n liste[i] = liste[i+1];\n liste[i+1] = temp;\n sorted = false;\n }\n }\n }\n return liste;\n }", "@Override\r\n\t public int compare(Student_UsingComparator obj1, Student_UsingComparator obj2){\n\t\t return obj2.rollno-obj1.rollno;\r\n\t }", "@Test \n public void compareFunctionalEquals() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p1, p1);\n \n assertEquals(0, a);\n }", "public static Comparator<Trio<Pair<String, Integer>, Pair<String,Integer>, Integer>> sortByWeight()\n\t{\n\t\tComparator<Trio<Pair<String, Integer>, Pair<String, Integer>, Integer>> comp = new Comparator<Trio<Pair<String, Integer>, Pair<String, Integer>, Integer>>() {\n\t\t\n\t\t\tpublic int compare(Trio<Pair<String, Integer>, Pair<String, Integer>, Integer> weight1,\n\t\t\t\t\tTrio<Pair<String, Integer>, Pair<String, Integer>, Integer> weight2) \n\t\t\t{\n\t\t\t\t\n\t\t\t\treturn weight1.getThird() - weight2.getThird();\n\t\t\t}\n\t\t};\n\t\t\n\t\treturn comp;\n\t}", "@Test\n public void compareFunctionalSmaller() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p2, p1);\n \n assertEquals(1, a);\n }", "public void sortKnowledgeBase()\n {\n int i;\n Random random;\n String aPredicate;\n StringTokenizer tokenizer;\n //------------\n random = new Random();\n i = 0;\n while (i < knowledgeBase.size())\n {\n aPredicate = knowledgeBase.get(i).commitments.get(0).predicate;\n tokenizer = new StringTokenizer(aPredicate,\"(), \");\n if(tokenizer.nextToken().equals(\"secuencia\"))\n knowledgeBase.get(i).priority = random.nextInt(100);\n //end if\n else\n knowledgeBase.get(i).priority = random.nextInt(10000);\n //end else\n i = i + 1;\n }//end while\n Collections.sort(knowledgeBase);\n }", "@Override\n\t\t\tpublic int compare(Entry<Integer, Double> o1, Entry<Integer, Double> o2) {\n\t\t\t\treturn -(int) (o1.getValue().compareTo(o2.getValue()));\n\t\t\t}", "@Override\n\t\t\tpublic int compare(Entry<String, Double> o1,\n\t\t\t\t\tEntry<String, Double> o2) {\n\t\t\t\tif(o1.getValue()>o2.getValue()){\n\t\t\t\t\treturn -1;\n\t\t\t\t}else if(o1.getValue()<o2.getValue()){\n\t\t\t\t\treturn 1;\n\t\t\t\t}else{\n\t\t\t\t\treturn 0;\n\t\t\t\t}\n\t\t\t}", "public int compareTo(Candidate c) {\r\n\t\treturn this.fitness_ < c.fitness_ ? -1 : this.fitness_ > c.fitness_ ? 1\r\n\t\t\t\t: 0;\r\n\t}", "@Override\n public int compareTo(final DistributionMember o) {\n // This is the most important bit.\n if (!getValue().equals(o.getValue())) return (int) Math.signum(o.getValue() - getValue());\n // The rest is arbitrary and just designed to keep non-identical DistributionMembers from being equal\n final List<Double> fitVals = getFitnessValues();\n final List<Double> otherVals = o.getFitnessValues();\n for (int i = 0; i < fitVals.size(); ++i) {\n if (!fitVals.get(i).equals(otherVals.get(i))) return (int) Math.signum(otherVals.get(i) - fitVals.get(i));\n }\n final Genotype g = getGenotype();\n final Genotype og = o.getGenotype();\n return g.compareTo(og);\n }", "private LinkedHashMap sortByValue(LinkedHashMap<Product, Double> linkedHashMap, Comparator<Double> comparator) {\n List<Map.Entry<Product, Double>> entries = new ArrayList<>(linkedHashMap.entrySet());\n LinkedHashMap<Product, Double> sorted = new LinkedHashMap<>();\n entries.stream()\n .sorted(Comparator.comparing(Map.Entry::getValue, comparator))\n .forEachOrdered(entry -> sorted.put(entry.getKey(), entry.getValue()));\n\n return sorted;\n }", "public DominanceComparator getComparator() {\r\n\t\treturn comparator;\r\n\t}", "public scala.collection.immutable.IndexedSeq<java.lang.Object> getQuantiles (scala.collection.Iterable<java.lang.Object> probabilities) { throw new RuntimeException(); }", "@Test\n public void testCompare() {\n AantalGastenComparator instance = new AantalGastenComparator();\n int expResult;\n int result;\n \n //test 1\n Accommodatie a1 = new Accommodatie(\"je moeder\", 30.00, 2, 1);\n Accommodatie a2 = new Accommodatie(\"je vader\", 40.00, 3, 1);\n expResult = -1;\n result = instance.compare(a1, a2);\n assertEquals(expResult, result);\n \n \n //test 2\n Accommodatie a3 = new Accommodatie(\"je moeder2\", 30.00, 2, 1);\n Accommodatie a4 = new Accommodatie(\"je vader2\", 40.00, 2, 1);\n expResult = 0;\n result = instance.compare(a3, a4);\n assertEquals(expResult, result);\n \n \n //test 3\n Accommodatie a5 = new Accommodatie(\"je moeder3\", 30.00, 3, 1);\n Accommodatie a6 = new Accommodatie(\"je vader3\", 40.00, 2, 1);\n expResult = 1;\n result = instance.compare(a5, a6);\n assertEquals(expResult, result);\n }", "public interface Comparator {\n default int compare(Object a, Object b) {\n FeatureExpr ctx = Contexts.model_java_util_Comparator_compare;\n V<?> compareResult = compare__Ljava_lang_Object_Ljava_lang_Object__I(V.one(ctx, a), V.one(ctx, b), ctx);\n V<?> selected = compareResult.select(ctx);\n assert selected.getOne() instanceof java.lang.Integer : \"compare returns non-Integer\";\n return ((java.lang.Integer) selected.getOne());\n }\n V<?> compare__Ljava_lang_Object_Ljava_lang_Object__I(V a, V b, FeatureExpr fe);\n}", "public int compare(Integer instIndex1, Integer instIndex2) {\n if (probs[instIndex1] > probs[instIndex2]) {\n return 1;\n } else if (probs[instIndex1] < probs[instIndex2]) {\n return -1;\n } else {\n return 0;\n }\n }", "@Override\n public int compareTo(Object o) { \n if(this.getGrade()==((BoardCandidate)o).getGrade()){\n return (int)(Math.random()*10-Math.random()*10);\n }\n return this.getGrade()-((BoardCandidate)o).getGrade();\n }", "public void sortElements(Comparator<TLProperty> comparator);", "public int compare(Candidate a, Candidate b) \n { \n return b.getNoOfVotes() - a.getNoOfVotes(); \n }", "private int comparator(int u, int synapSum){\n\t\treturn synapSum >= u ? 1 : 0;\n\t}", "@Test\r\n public void testCompare() {\r\n\r\n double[] r1;\r\n double[] r2;\r\n Comparator<double[]> instance = new DoubleArrayComparator();\r\n \r\n r1 = new double[]{1,2,3};\r\n r2 = new double[]{1,2,3}; \r\n assertEquals(0, instance.compare(r1, r2));\r\n\r\n r1 = new double[]{1,2,3};\r\n r2 = new double[]{1,3,2}; \r\n assertEquals(-1, instance.compare(r1, r2));\r\n \r\n r1 = new double[]{1,3,3};\r\n r2 = new double[]{1,3,2}; \r\n assertEquals(1, instance.compare(r1, r2));\r\n \r\n }", "public int compare(Object o1, Object o2) {\n int[] p1 = (int[]) o1;\n int[] p2 = (int[]) o2;\n\n // compare sum of axis distances for each priority\n for (int p=MAX_PRIORITY; p>=MIN_PRIORITY; p--) {\n int dist1 = 0, dist2 = 0;\n for (int i=0; i<p1.length; i++) {\n if (priorities[i] == p) {\n dist1 += distance(i, p1[i]);\n dist2 += distance(i, p2[i]);\n }\n }\n int diff = dist1 - dist2;\n if (diff != 0) return diff;\n }\n\n // compare number of diverging axes for each priority\n for (int p=MAX_PRIORITY; p>=MIN_PRIORITY; p--) {\n int div1 = 0, div2 = 0;\n for (int i=0; i<p1.length; i++) {\n if (priorities[i] == p) {\n if (p1[i] != 0) div1++;\n if (p2[i] != 0) div2++;\n }\n }\n int diff = div1 - div2;\n if (diff != 0) return diff;\n }\n\n return 0;\n }", "@Override\r\n\t\t\tpublic int compare(Presentor o1, Presentor o2) {\n\t\t\t\tint sort = 0;\r\n\t\t\t\tint a = o1.getZs() - o2.getZs();\r\n\t\t\t\tif (a != 0) {\r\n\t\t\t\t\tsort = (a < 0) ? 1 : -1;\r\n\t\t\t\t} else {\r\n\t\t\t\t\ta = o1.getJd() - o2.getJd();\r\n\t\t\t\t\tif (a != 0) {\r\n\t\t\t\t\t\tsort = (a < 0) ? 1 : -1;\r\n\t\t\t\t\t}\r\n\t\t\t\t}\r\n\t\t\t\treturn sort;\r\n\t\t\t}", "public interface IStoppingCriteria {\n\n /**\n * Determine the degree of clustering agreement\n * @param cluster1 one clustering results\n * @param cluster2 the other clustering results\n * @return the degree of clustering agreement; 1 refers to be the same clustering results; 0 refers to be the totally different clustering results\n */\n public double computeSimilarity(int[] cluster1, int[] cluster2);\n\n}", "@Override\n\t\t\t\tpublic int compare(Integer a, Integer b) {\n\t\t\t\t\tInteger x= (Integer)P[a];\n\t\t\t\t\tInteger y= (Integer)P[b];\n\t\t\t\t\treturn x.compareTo(y);\n\t\t\t\t}", "private static void SortHash(HashMap<String,ArrayList<input>> hashMap,Distribution list)\n\t{\n\t\tCollections.sort(list.First, new Comparator<input>() {\n\t\t public int compare(input one, input other) {\n\t\t \tif(one.sum>other.sum)\n\t\t \t{\n\t\t \t\treturn 1;\n\t\t \t}\n\t\t \telse\n\t\t \t{\n\t\t \t\treturn -1;\n\t\t \t}\n\t\t }\n\t\t}); \n\t\tCollections.sort(list.Second, new Comparator<input>() {\n\t\t public int compare(input one, input other) {\n\t\t \tif(one.sum>other.sum)\n\t\t \t{\n\t\t \t\treturn 1;\n\t\t \t}\n\t\t \telse\n\t\t \t{\n\t\t \t\treturn -1;\n\t\t \t}\n\t\t }\n\t\t}); \n\t\tCollections.sort(list.Third, new Comparator<input>() {\n\t\t public int compare(input one, input other) {\n\t\t \tif(one.sum>other.sum)\n\t\t \t{\n\t\t \t\treturn 1;\n\t\t \t}\n\t\t \telse\n\t\t \t{\n\t\t \t\treturn -1;\n\t\t \t}\n\t\t }\n\t\t}); \n\t\tCollections.sort(list.Fourth, new Comparator<input>() {\n\t\t public int compare(input one, input other) {\n\t\t \tif(one.sum>other.sum)\n\t\t \t{\n\t\t \t\treturn 1;\n\t\t \t}\n\t\t \telse\n\t\t \t{\n\t\t \t\treturn -1;\n\t\t \t}\n\t\t }\n\t\t}); \n\t\tCollections.sort(list.Fifth, new Comparator<input>() {\n\t\t public int compare(input one, input other) {\n\t\t \tif(one.sum>other.sum)\n\t\t \t{\n\t\t \t\treturn 1;\n\t\t \t}\n\t\t \telse\n\t\t \t{\n\t\t \t\treturn -1;\n\t\t \t}\n\t\t }\n\t\t}); \n\t\tCollections.reverse(list.First);\n\t\tCollections.reverse(list.Second);\n\t\tCollections.reverse(list.Third);\n\t\tCollections.reverse(list.Fourth);\n\t\tCollections.reverse(list.Fifth);\n\t\tputInHashMap(hashMap,list);\n\t}", "SortComparator(Map<Integer, Integer> tFreqMap) { \n this.freqMap = tFreqMap; \n }", "public int compare(Object o1, Object o2) {\n/* 25 */ Alphabet a1 = (Alphabet)o1;\n/* 26 */ Alphabet a2 = (Alphabet)o2;\n/* */ \n/* 28 */ return a2.order - a1.order;\n/* */ }", "@Override\n\tpublic int compareTo(PredictProbPair o) {\n\t\tif (keylen == o.keylen)\n\t\t{\n\t\t\treturn ((Double)(-prob)).compareTo((Double)(-o.prob));\n\t\t}\n\t\treturn ((Integer)(-keylen)).compareTo((Integer)(-o.keylen));\n\t}", "@Override\n\t\t\tpublic int compare(Entry<String, Double> o1, Entry<String, Double> o2) {\n\t\t\t\treturn o1.getValue().compareTo(o2.getValue());\n\t\t\t}", "public DatasetEuklidianComparator(Dataset candidate){\n this.candidate = candidate;\n }", "public Comparator<Human> getLikelinessToGetKilledComparator() {\n return new Comparator<Human>() {\n @Override\n public int compare(Human human1, Human human2) {\n return (int) (100 * (human1.getLikelinessToGetKilled()\n - human2.getLikelinessToGetKilled()));\n }\n };\n }", "@Override\r\n\tpublic int compareTo(CandidateDoc o) {\n\t\tif((score-o.score)>0)\r\n\t\t{\r\n\t\t\treturn 1;\r\n\t\t}else if((score-o.score)<0)\r\n\t\t{\r\n\t\t\treturn -1;\r\n\t\t}else\r\n\t\t{\r\n\t\t\treturn 0;\r\n\t\t}\r\n\r\n\t}", "public PriceComparator()\n\t{\n\t\tascending=true;\n\t}", "@Override\n public int compare(CostVector o1, CostVector o2) {\n int i = 0;\n while (i < o1.getCosts().length && o1.getCosts()[i] == o2.getCosts()[i]) {\n i++;\n }\n if (i != o1.getCosts().length) {\n return o1.getCosts()[i] > o2.getCosts()[i] ? 1 : -1;\n } else {\n return 0;\n }\n }", "public LessThan() {\n this.toCompare = new double[2];\n this.index = 0;\n }", "private Comparator<Integer> getIntegerComparator() {\n return new Comparator<Integer>() {\n @Override\n public int compare(Integer integer1, Integer integer2) {\n return integer1 - integer2;\n }\n };\n }", "private void sortByWeight()\n\t{\n\t\tfor(int i=1; i<circles.size(); i++)\n\t\t{\n\t\t\tPVCircle temp = circles.get(i);\n\t\t\tint thisWeight = circles.get(i).getWeight();\n\t\t\tint j;\n\t\t\tfor(j=i-1; j>=0; j--)\n\t\t\t{\n\t\t\t\tint compWeight = circles.get(j).getWeight();\n\t\t\t\tif(thisWeight < compWeight)\n\t\t\t\t\tbreak;\n\t\t\t\telse\n\t\t\t\t\tcircles.set(j+1, circles.get(j));\n\t\t\t}\n\t\t\tcircles.set(j+1, temp);\n\t\t}\n\t\t\n\t}", "float getSpecialProb();", "@Override\n public int compare(Object arg0, Object arg1) {\n int a = arg0.hashCode();\n int b = arg1.hashCode();\n int accum;\n if (a == b) {\n accum = 0;\n } else if (a > b) {\n accum = 1;\n } else {\n accum = -1;\n }\n return accum;\n }", "private SortedSet<Classification<F, C>> categoryProbabilities(Collection<F> features) {\n\n /*\n * Sort the set according to the possibilities. Because we have to sort\n * by the mapped value and not by the mapped key, we can not use a\n * sorted tree (TreeMap) and we have to use a set-entry approach to\n * achieve the desired functionality. A custom comparator is therefore\n * needed.\n */\n SortedSet<Classification<F, C>> probabilities =\n new TreeSet<Classification<F, C>>(new Comparator<Classification<F, C>>() {\n\n @Override\n public int compare(Classification<F, C> o1, Classification<F, C> o2) {\n int toReturn = Double.compare(o1.getProbability(), o2.getProbability());\n if ((toReturn == 0) && !o1.getCategory().equals(o2.getCategory())) {\n toReturn = -1;\n }\n return toReturn;\n }\n });\n\n for (C category : this.getCategories()) {\n probabilities.add(new Classification<F, C>(\n features, category, this.categoryProbability(features, category)));\n }\n return probabilities;\n }", "@Override\r\n\tpublic int compare(Student_UsingComparator o1, Student_UsingComparator o2) {\n\t\treturn o1.studentage-o2.studentage;\r\n\t}", "public int compareTo(Chromosome ch){\r\n\r\n if(_FitVal > ch.FitVal())\r\n return 1;\r\n else if(_FitVal < ch.FitVal())\r\n return -1;\r\n else\r\n return 0;\r\n }", "@Override\n\t\t\tpublic int compare(Entry<String, Double> o1,\n\t\t\t\t\tEntry<String, Double> o2) {\n\t\t\t\tDouble v2 = o2.getValue();\n\t\t\t\tDouble v1 = o1.getValue();\n\t\t\t\treturn v2.compareTo(v1);\n\t\t\t}", "int compFunction(int code) {\r\n if (code % num_buckets < 0) {\r\n return (code % num_buckets) + num_buckets;\r\n } else {\r\n return code % num_buckets;\r\n } \r\n /*int a = 13;\r\n int b = 23;\r\n int p = 1000000 * num_buckets;\r\n while (isPrime(p) == false) { \r\n p += 1; \r\n }\r\n return ((a * code + b) % p) % num_buckets; */\r\n }", "public static Comparator<Card> createByRankComparator()\n {\n return new Comparator<Card>()\n {\n public int compare(Card pCard1, Card pCard2)\n {\n return pCard1.aRank.compareTo(pCard2.aRank);\n }\n };\n }", "Comparator<? super K> comparator();", "AlgDistribution getDistribution();", "public abstract void compare();", "@Override\n public int compare(Recognition lhs, Recognition rhs) {\n return Float.compare(rhs.getConfidence(), lhs.getConfidence());\n }", "private void sort() {\n ScoreComparator comparator = new ScoreComparator();\n Collections.sort(scores, comparator);\n }", "public String toString(){\n\t\treturn \"Bernouli distribution [probability = \" + getProbability() + \"]\";\n\t}", "public static void main(String[] args) {\n Circle[] circles = new Circle[3];\n circles[0] = new Circle(3.6);\n circles[1] = new Circle();\n circles[2] = new Circle(3.5, \"indigo\", false);\n System.out.println(\"Pre-sorted: \");\n for (Circle circle:circles){\n System.out.println(circle);\n }\n\n Comparator circleComparator = new CircleComparator();\n Arrays.sort(circles,circleComparator);\n\n System.out.println(\"After-sorted: \");\n for (Circle circle:circles){\n System.out.println(circle);\n }\n /*ComparableCircle[] circles= new ComparableCircle[3];\n circles[0]= new ComparableCircle(3.6);\n circles[1]=new ComparableCircle();\n circles[2]=new ComparableCircle(\"blue\",true,3.4);\n System.out.println(\"Pre-sorted:\");\n for(ComparableCircle circle:circles) {\n System.out.println(circle);\n }\n System.out.println(circles[0].compareTo(circles[1]));\n System.out.println(circles[1].compareTo(circles[2]));\n System.out.println(circles[0].compareTo(circles[2]));\n\n Arrays.sort(circles);\n\n System.out.println(\"After-sorted: \");\n for(ComparableCircle circle:circles){\n System.out.println(circle);\n }*/\n }", "public void testCompare2() throws Exception {\r\n ComponentCompetitionSituation situation = new ComponentCompetitionSituation();\r\n ComponentCompetitionPredictor predictor = new ComponentCompetitionPredictor();\r\n ComponentCompetitionFulfillmentPrediction prediction1 = new ComponentCompetitionFulfillmentPrediction(1.0D,\r\n situation, predictor);\r\n ComponentCompetitionFulfillmentPrediction prediction2 = new ComponentCompetitionFulfillmentPrediction(0.6D,\r\n situation, predictor);\r\n\r\n begin();\r\n\r\n for (int i = 0; i < TIMES; i++) {\r\n // predictions in range < predictions below the range\r\n int result = comparator.compare(prediction1, prediction2);\r\n // result should be < 0\r\n assertTrue(\"result of compare\", result < 0);\r\n }\r\n\r\n print(\"ComponentCompetitionFulfillmentPredictionPrizeComparator#compare\");\r\n }", "@Override\r\n\t\t\tpublic int compare(DjikstraPair o1, DjikstraPair o2) {\n\t\t\t\treturn o2.csf - o1.csf;\r\n\t\t\t}", "public void testCompare1() throws Exception {\r\n ComponentCompetitionSituation situation = new ComponentCompetitionSituation();\r\n ComponentCompetitionPredictor predictor = new ComponentCompetitionPredictor();\r\n ComponentCompetitionFulfillmentPrediction prediction1 = new ComponentCompetitionFulfillmentPrediction(1.0D,\r\n situation, predictor);\r\n ComponentCompetitionFulfillmentPrediction prediction2 = new ComponentCompetitionFulfillmentPrediction(1.5D,\r\n situation, predictor);\r\n\r\n begin();\r\n\r\n for (int i = 0; i < TIMES; i++) {\r\n // predictions in range < predictions above the range\r\n int result = comparator.compare(prediction1, prediction2);\r\n // result should be < 0\r\n assertTrue(\"result of compare\", result < 0);\r\n }\r\n\r\n print(\"ComponentCompetitionFulfillmentPredictionPrizeComparator#compare\");\r\n }", "@Override\n\tpublic int compare(WritableComparable a, WritableComparable b) {\n\t\tFloatWritable key1 = (FloatWritable) a;\n\t\tFloatWritable key2 = (FloatWritable) b;\n\n\t\t// Implemet sorting in descending order\n\t//\tint result = key1.get() < key2.get() ? 1 : key1.get() == key2.get() ? 0 : -1;\n\t\treturn -1 * key1.compareTo(key2);\n\t}", "@Override\n public int compare(Student s1, Student s2) {\n return (int)(1000*(s2.getGPA()-s1.getGPA()));\n }", "private double estimateCategoricalPropertyProb(TemporalElementStats stats1, String property1,\n Comparator comp,\n TemporalElementStats stats2, String property2) {\n Map<String, Map<PropertyValue, Double>> map1 =\n stats1.getCategoricalSelectivityEstimation();\n Map<String, Map<PropertyValue, Double>> map2 =\n stats2.getCategoricalSelectivityEstimation();\n Map<PropertyValue, Double> propStats1 = map1.getOrDefault(property1, null);\n Map<PropertyValue, Double> propStats2 = map2.getOrDefault(property2, null);\n // property not sampled or not considered\n if (propStats1 == null || propStats2 == null) {\n // property not considered => return 0.5\n if (!isPropertyRelevant(property1) && !isPropertyRelevant(property2)) {\n return 0.5;\n } else {\n // property not sampled => very rare => return very small value\n return 0.0001;\n }\n }\n if (comp == EQ || comp == NEQ) {\n double sum = 0.;\n for (Map.Entry<PropertyValue, Double> entry1 : propStats1.entrySet()) {\n double val1Selectivity = entry1.getValue();\n for (Map.Entry<PropertyValue, Double> entry2 : propStats2.entrySet()) {\n if (entry1.getKey().equals(entry2.getKey())) {\n double val2Selectivity = entry2.getValue();\n sum += val1Selectivity * val2Selectivity;\n }\n }\n }\n return comp == EQ ? sum : 1. - sum;\n } else {\n // shouldn't happen, categorical variables can only be compared with EQ or NEQ\n return 0.;\n }\n }", "@Override\n\t\t\t\tpublic int compare(Integer o1, Integer o2) {\n\t\t\t\t\treturn points[o2][0]*points[o2][0]+points[o2][1]*points[o2][1]-points[o1][0]*points[o1][0]-points[o1][1]*points[o1][1];\n\t\t\t\t}", "private double estimateNumericalPropertyProb(List<TemporalElementStats> relevantStats, String property,\n Comparator comp, PropertyValue value) {\n long overallCount = 0L;\n for (TemporalElementStats stat : relevantStats) {\n overallCount += stat.getElementCount();\n }\n double sum = 0.;\n for (TemporalElementStats stat : relevantStats) {\n sum += estimateNumericalPropertyProb(stat, property, comp, value) *\n (((double) stat.getElementCount() / overallCount));\n }\n return sum;\n }", "public void generatePriority() {\n\t\tpriority = .25 * frequency + .25 * age + .25 * links + .25 * money;\n\t}", "@SuppressWarnings(\"unchecked\")\r\n public static HashMap<Integer,TreeMap<Integer,Double>> word_distribute(Corpus c, SparseBackoffTree [] sbtToOutput) throws Exception{\n @SuppressWarnings(\"rawtypes\")\r\n HashMap<Integer,HashMap<Integer,Double>> word_givenTopic = new HashMap();\r\n for(int i = 0; i < c._pWord.length; i++) {\r\n if(c._pWord[i] > 0.0) {\r\n TIntDoubleHashMap hm = sbtToOutput[i].getLeafCounts();\r\n TIntDoubleIterator it = hm.iterator();\r\n while(it.hasNext()) {\r\n it.advance();\r\n int sId = it.key();\r\n double val = it.value()/c._pWord[i];\r\n if(word_givenTopic.containsKey(sId)){\r\n HashMap<Integer,Double> sublist = word_givenTopic.get(sId);\r\n sublist.put(i,val);\r\n }else{\r\n @SuppressWarnings(\"rawtypes\")\r\n HashMap<Integer,Double> sublist = new HashMap();\r\n sublist.put(i,val);\r\n word_givenTopic.put(sId,sublist);\r\n }\r\n }\r\n }\r\n }\r\n\r\n //sort the hash map by value.\r\n @SuppressWarnings(\"rawtypes\")\r\n HashMap<Integer,TreeMap<Integer,Double>> final_result = new HashMap();\r\n for(Entry<Integer, HashMap<Integer, Double>> entry : word_givenTopic.entrySet()) {\r\n int key = entry.getKey();\r\n HashMap<Integer,Double> word_distribution = entry.getValue();\r\n ByValueComparator bvc = new ByValueComparator(word_distribution);\r\n TreeMap<Integer, Double> sorted_word_distribution = new TreeMap<Integer, Double>(bvc);\r\n sorted_word_distribution.putAll(word_distribution);\r\n final_result.put(key,sorted_word_distribution);\r\n } \r\n return final_result;\r\n}", "public int compareTo(Object profs) {\n\t\treturn 0;\n\t}", "int compFunction(int code) {\n return Math.abs(((3 * code + 8) % largePrime) % buckets.length);\n }", "@Transient\n\tpublic static Comparator<Requerimiento> getComparator(){\n\t\treturn new Comparator<Requerimiento>(){\n\t\t\tpublic int compare(Requerimiento requer1, Requerimiento requer2) {\n\t\t\t\treturn requer1.getIdRequerimiento().compareTo(requer2.getIdRequerimiento());\n\t\t\t}\n\t\t};\n\t}", "public void sort()\n\t{\n\t\tfor(int i=0;i<bowlers.size()-1;i++)\n\t\t{\n\t\t\tfor(int j=i+1;j<bowlers.size();j++)\n\t\t\t{\n\t\t\t\tif(bowlers.get(i).getBall()<bowlers.get(j).getBall())\n\t\t\t\t{\n\t\t\t\t\tBowler bowler=bowlers.get(i);\n\t\t\t\t\tbowlers.set(i,bowlers.get(j));\n\t\t\t\t\tbowlers.set(j,bowler);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tfor(int i=0;i<bowlers.size();i++)\n\t\t{\n\t\tSystem.out.println(bowlers.get(i).getBall());\n\t\t}\n\t}", "@Override\n\t\tpublic int compare(Pecosa a, Pecosa b) {\n\t\t\tLong numa=a.getId().getPecnro();\n\t\t\tLong numb=b.getId().getPecnro();\n\t\t\treturn (int)(numa-numb);\n\t\t}", "private static void sortingMemo() {\n\t\t\n\t}", "@Override\n\tpublic int compareTo(Object o)\n\t{\n\t\tif (o instanceof ParticleRenderData)\n\t\t{\n\t\t\tParticleRenderData other = (ParticleRenderData) o;\n\t\t\tif (other.camDist > this.camDist)\n\t\t\t\treturn -1;\n\t\t\tif (other.camDist < this.camDist)\n\t\t\t\treturn 1;\n\t\t}\n\t\treturn 0;\n\t}", "public int compareToPri(YuanC_LuH_Food a)\n\t{\n\t\tif(price<a.getPrice())\n\t\t\treturn -1;\n\t\telse if(price>a.getPrice())\n\t\t\treturn 1;\n\t\telse\n\t\t\treturn 0;\n\t}", "private double estimateNumericalPropertyProb(List<TemporalElementStats> relevantStats1, String property1,\n Comparator comp, List<TemporalElementStats> relevantStats2,\n String property2) {\n long count1 = relevantStats1.stream()\n .map(TemporalElementStats::getElementCount)\n .reduce(0L, Long::sum);\n long count2 = relevantStats2.stream()\n .map(TemporalElementStats::getElementCount)\n .reduce(0L, Long::sum);\n long totalCount = count1 * count2;\n\n double outerSum = 0.;\n for (TemporalElementStats s1 : relevantStats1) {\n double innerSum = 0.;\n for (TemporalElementStats s2 : relevantStats2) {\n double prob = estimateNumericalPropertyProb(s1, property1, comp, s2, property2);\n double weight = ((double) s1.getElementCount() * s2.getElementCount()) /\n totalCount;\n innerSum += prob * weight;\n }\n outerSum += innerSum;\n }\n return outerSum;\n }", "public Comparator<Point> slopeOrder() {\n /* YOUR CODE HERE */\n return new SlopeOrder();\n }", "@Override\n public int compare(Sample s1, Sample s2) {\n if (s1.positive_features.size() < s2.positive_features.size())\n return -1;\n else if (s1.positive_features.size() > s2.positive_features.size())\n return +1;\n else {\n for (int i = 0; i < s1.positive_features.size(); i++) {\n int v1 = s1.positive_features.get(i);\n int v2 = s2.positive_features.get(i);\n if (v1 < v2) return -1;\n if (v1 > v2) return +1;\n }\n return 0;\n }\n }", "@Override\n public int compare(Prediction lhs, Prediction rhs) {\n return Float.compare(rhs.getConfidence(), lhs.getConfidence());\n }", "private double estimateCategoricalPropertyProb(List<TemporalElementStats> relevantStats, String property,\n Comparator comp, PropertyValue value) {\n if (comp != EQ && comp != NEQ) {\n return 0.;\n }\n long overallCount = 0L;\n boolean found = false;\n for (TemporalElementStats stat : relevantStats) {\n overallCount += stat.getElementCount();\n if (stat.getCategoricalSelectivityEstimation().containsKey(property)) {\n found = true;\n }\n }\n // property not sampled or not considered\n if (!found) {\n // not relevant/considered => simply return 0.5\n if (!isPropertyRelevant(property)) {\n return 0.5;\n } else {\n // not sampled => very rare or not even there => return very small value\n return 0.0001;\n }\n }\n\n double prob = 0.;\n for (TemporalElementStats stat : relevantStats) {\n if (!stat.getCategoricalSelectivityEstimation().containsKey(property)) {\n // not sampled ? ....\n double factor = 0.0001;\n // ...or just excluded/not relevant?\n if (!isPropertyRelevant(property)) {\n factor = 0.5;\n }\n prob += factor * ((double) stat.getElementCount() / overallCount);\n continue;\n }\n prob += stat.getCategoricalSelectivityEstimation()\n .get(property)\n .getOrDefault(value, 0.0001) *\n ((double) stat.getElementCount() / overallCount);\n }\n if (comp == EQ) {\n return prob;\n } else {\n //NEQ\n return 1 - prob;\n }\n }", "@Override\n\t\tpublic int compareTo(student that) {\n\t\t\treturn that.gpa - this.gpa;\n\t\t}", "@Override\n public int compareTo(AComponent comp) {\n int comparedPriority = comp.getPriority();\n return priority - comparedPriority;\n }" ]
[ "0.6811209", "0.62138355", "0.61119336", "0.5770945", "0.5763723", "0.5637151", "0.5632833", "0.5626401", "0.56248254", "0.56248254", "0.5622052", "0.5607154", "0.5512504", "0.54979914", "0.5478693", "0.547383", "0.5455216", "0.5455139", "0.54531664", "0.544864", "0.544583", "0.5424542", "0.5411287", "0.540316", "0.5389725", "0.5385918", "0.53779054", "0.5375959", "0.53698045", "0.5365249", "0.5360612", "0.5352629", "0.53476214", "0.5344519", "0.5339307", "0.5327777", "0.53202796", "0.5317911", "0.5316873", "0.5309983", "0.53075826", "0.5288165", "0.5286741", "0.5286154", "0.52749175", "0.5268051", "0.52604187", "0.52602816", "0.52367353", "0.5230534", "0.522847", "0.52278334", "0.5220777", "0.5220366", "0.5217612", "0.5216741", "0.52086616", "0.5207496", "0.5187953", "0.5180548", "0.517474", "0.5170894", "0.5167884", "0.5165942", "0.51560056", "0.51547664", "0.5144381", "0.5141043", "0.514064", "0.51371026", "0.5137027", "0.51303023", "0.51270753", "0.512129", "0.51211345", "0.51187253", "0.5112064", "0.5107031", "0.5104798", "0.5103313", "0.5101191", "0.50982374", "0.5097535", "0.50925064", "0.5091554", "0.5089648", "0.508934", "0.5075718", "0.50748694", "0.5071683", "0.50677925", "0.5057805", "0.50548637", "0.50521415", "0.50498134", "0.50463325", "0.5043417", "0.5039146", "0.50372285", "0.5036178", "0.503544" ]
0.0
-1
TODO watch out, this doesn't appear in operator_less
@Override public int compare(Sample s1, Sample s2) { if (s1.positive_features.size() < s2.positive_features.size()) return -1; else if (s1.positive_features.size() > s2.positive_features.size()) return +1; else { for (int i = 0; i < s1.positive_features.size(); i++) { int v1 = s1.positive_features.get(i); int v2 = s2.positive_features.get(i); if (v1 < v2) return -1; if (v1 > v2) return +1; } return 0; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private boolean less(Comparable a, Comparable b) {\n return a.compareTo(b) < 0;\n }", "private static boolean lt(Comparable lhs, Comparable rhs) \n {\n return lhs.compareTo(rhs) < 0;\n }", "@Test\n\tpublic void lessThanTest() {\n\t\tassertTrue(x.less(y));\n\t\tassertFalse(y.less(x));\n\t}", "public static BinaryExpression lessThan(Expression expression0, Expression expression1) { throw Extensions.todo(); }", "@Override\n public boolean isLess(Query e1, Query e2) {\n return this.compare(e1,e2) == this.LESS;\n }", "protected static boolean less(Comparable a, Comparable b) {\n\t\treturn a.compareTo(b) < 0;\r\n\t}", "final boolean operator_less(final Sample x) {\n for (int i = 0; i < positive_features.size(); i++) {\n if (i >= x.positive_features.size()) return false;\n int v0 = positive_features.get(i);\n int v1 = x.positive_features.get(i);\n if (v0 < v1) return true;\n if (v0 > v1) return false;\n }\n return false;\n }", "private Expr comparison() {\n Expr expr = addition();\n\n while(match(GREATER, GREATER_EQUAL, LESS, LESS_EQUAL)) { // These variable length arguments are real convenient\n Token operator = previous();\n Expr right = addition();\n expr = new Expr.Binary(expr, operator, right);\n }\n\n return expr;\n }", "BooleanExpression lt(ComparableExpression<? extends T> expr);", "private static boolean less(Comparable v, Comparable w) {\n return v.compareTo(w) < 0;\n }", "private static boolean less(Comparable v, Comparable w) {\n return v.compareTo(w) < 0;\n }", "private static boolean less(Comparable v, Comparable w) {\n return v.compareTo(w) < 0;\n }", "@Override\n\tpublic void visit(LessNode node) {\n\t\tif (Evaluator.checkScope(node) == false) {\n\t\t\treturn;\n\t\t}\n\n\t\tif (Evaluator.checkAssert(node) == false) {\n\t\t\treturn;\n\t\t}\n\t\t/**\n\t\t * evaluam expresiile din cei 2 fii\n\t\t */\n\t\tEvaluator.evaluate(node.getChild(0));\n\t\tEvaluator.evaluate(node.getChild(1));\n\n\t\tInteger s2 = 0;\n\t\tInteger s1 = 0;\n\t\t/**\n\t\t * preluam rezultatele evaluarii si verificam daca primul este mai mic\n\t\t * decat la doilea ,setand corespunzator valoarea din nodul curent in\n\t\t * functie de rezultatul comparatiei\n\t\t */\n\t\tif (node.getChild(0) instanceof Variable) {\n\t\t\ts1 = Integer.parseInt(Evaluator.variables.get(node.getChild(0).getName()));\n\t\t} else {\n\t\t\ts1 = Integer.parseInt(node.getChild(0).getName());\n\t\t}\n\t\tif (node.getChild(1) instanceof Variable) {\n\t\t\ts2 = Integer.parseInt(Evaluator.variables.get(node.getChild(1).getName()));\n\t\t} else {\n\t\t\ts2 = Integer.parseInt(node.getChild(1).getName());\n\t\t}\n\n\t\tif (s1 < s2) {\n\t\t\tnode.setName(\"true\");\n\t\t} else {\n\t\t\tnode.setName(\"false\");\n\t\t}\n\t}", "private static boolean less(Comparable v, Comparable w) {\n return (v.compareTo(w) < 0);\n }", "public static BinaryExpression lessThan(Expression expression0, Expression expression1, boolean liftToNull, Method method) { throw Extensions.todo(); }", "private static boolean less(Comparable v, Comparable w)\n\t{\n\t\tif(v.compareTo(w)<0) {\n\t\t\treturn true; \n\t\t}\n\t\treturn false; \n\t}", "private static boolean less(Comparable p, Comparable q) {\n return p.compareTo(q) < 0;\n }", "public LessThan() {\n this.toCompare = new double[2];\n this.index = 0;\n }", "private static <Key extends Comparable<Key>> boolean less(Key v, Key w) \n\t{\n\t\treturn (v.compareTo (w) < 0);\n\t}", "ComparableExpression<T> min();", "default boolean gt(int lhs, int rhs) {\r\n return lt(rhs,lhs);\r\n }", "protected Expression convertLex_less(Sequence seq) throws SugarException {\n converter.checkArity(seq, 2);\n if (!seq.get(1).isSequence() || !seq.get(2).isSequence()) {\n converter.syntaxError(seq);\n }\n if (!Converter.DECOMPOSE_LEX_LESS) {\n return seq.hold();\n }\n Sequence seq1 = (Sequence) seq.get(1);\n Sequence seq2 = (Sequence) seq.get(2);\n int n = seq1.length();\n if (n == 0 || n != seq2.length()) {\n converter.syntaxError(seq);\n }\n Expression x = seq1.get(n - 1).lt(seq2.get(n - 1));\n for (int i = n - 2; i >= 0; i--) {\n Expression x1 = seq1.get(i);\n Expression x2 = seq2.get(i);\n x = (x1.le(x2)).and((x1.eq(x2)).imp(x));\n }\n return x;\n }", "@Override\n public boolean lessThan(Object o1, Object o2) {\n return ((MI)o1).value < ((MI)o2).value;\n }", "private boolean iflt(PyObject x, PyObject y) {\n \n if (this.compare == null) {\n /* NOTE: we rely on the fact here that the sorting algorithm\n only ever checks whether k<0, i.e., whether x<y. So we\n invoke the rich comparison function with _lt ('<'), and\n return -1 when it returns true and 0 when it returns\n false. */\n return x._lt(y).__nonzero__();\n }\n \n PyObject ret = this.compare.__call__(x, y);\n \n if (ret instanceof PyInteger) {\n int v = ((PyInteger)ret).getValue();\n return v < 0;\n }\n throw Py.TypeError(\"comparision function must return int\");\n }", "public boolean lessThan(NumberP other)\n {\n \treturn OperationsCompareTo.CompareDouble(this, other) == -1;\n }", "String getLess();", "@Test\n public void compareFunctionalSmaller() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p2, p1);\n \n assertEquals(1, a);\n }", "Condition lessThan(QueryParameter parameter, Object x);", "List<Object> lessThanOrEqualsTo(Object value);", "public static final int[] get_LESS_EQUAL(){\n\t\treturn get_LESS();\n\t}", "private static boolean less(Student v, Student w) {\r\n if (v == w) return false; // optimization when reference equals\r\n return v.compareTo(w) < 0;\r\n }", "BooleanExpression lt(T t);", "@Override\n public InterpreterValue smaller(InterpreterValue v) {\n\n // If the given value is a IntegerValue then check if the value is smaller than\n // the own value and return a BooleanValue\n if(v instanceof IntegerValue) return BooleanValue.from(getValue() < ((IntegerValue) v).getValue());\n\n // If the given value is a DoubleValue then check if the value is smaller than\n // the own value and return a BooleanValue\n if(v instanceof DoubleValue) return BooleanValue.from(getValue() < ((DoubleValue) v).getValue());\n\n // In other case just throw an error\n throw new Error(\"Operator '<' is not defined for type integer and \" + v.getName());\n\n }", "public static BinaryExpression lessThanOrEqual(Expression expression0, Expression expression1) { throw Extensions.todo(); }", "@Override\r\n\tpublic boolean isLessThan(Node node) {\n\t\treturn false;\r\n\t}", "@Override\n\t\tprotected boolean lessThan(final Entry hitA, final Entry hitB) {\n\t\t\tassert hitA != hitB;\n\t\t\tassert hitA.mSlot != hitB.mSlot;\n\n\t\t\tfinal int c = mOneReverseMul * mFirstComparator.compare(hitA.mSlot, hitB.mSlot);\n\t\t\tif (c != 0) \n\t\t\t\treturn c > 0;\n\n\t\t\t\t// avoid random sort order that could lead to duplicates (bug #31241):\n\t\t\t\treturn hitA.getDoc() > hitB.getDoc();\n\t\t}", "public AbstractBoolean less(Interval other){\n\t\ttry {\n\t\t\t// If this.max < this.min then True\n\t\t\tif ((!this.high.equals(\"+Inf\"))\n\t\t\t\t\t&& (!other.low.equals(\"-Inf\"))\n\t\t\t\t\t&& Integer.parseInt(this.high) < Integer.parseInt(other.low))\n\t\t\t\treturn AbstractBoolean.True();\n\n\t\t\t// If this.min > other.max then False\n\t\t\tif ((!other.high.equals(\"+Inf\"))\n\t\t\t\t\t&& (!this.low.equals(\"-Inf\"))\n\t\t\t\t\t&& Integer.parseInt(this.low) > Integer.parseInt(other.high))\n\t\t\t\treturn AbstractBoolean.False();\n\n\t\t} catch (NumberFormatException e){\n\t\t\treturn AbstractBoolean.TopBool();\n\t\t}\n\n\t\treturn AbstractBoolean.TopBool();\n\t}", "private static <E extends Comparable<? super E>, V> boolean less(final E nonnull, final E other) {\r\n if (other == null) return true;\r\n return nonnull.compareTo(other) < 0;\r\n }", "String getGreater();", "Object findOperatorNeedCheck();", "public static EqualityExpression lt(String propertyName, Object value) {\n return new EqualityExpression(Operator.LESS_THAN, propertyName, value);\n }", "@Test\n public void compareFunctionalBigger() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p1, p2);\n \n assertEquals(-1, a);\n\n }", "public T caseLessThan(LessThan object) {\n\t\treturn null;\n\t}", "@Test\n public void testCompareToLess() {\n assertTrue(o1.compareTo(o_test) < 0);\n }", "public Value<?> lt(Value<?> v) {\r\n Integer cmp = compare(v);\r\n if (cmp == null)\r\n throw unsupported(\"<\", v);\r\n return new ValueBoolean(cmp < 0);\r\n }", "public static Object lt(Object val1, Object val2) {\n\t\tif (isFloat(val1) && isFloat(val2)) {\n\t\t\treturn ((BigDecimal) val1).compareTo((BigDecimal) val2) < 0;\n\t\t} else if (isInt(val1) && isInt(val2)) {\n\t\t\treturn ((BigInteger) val1).compareTo((BigInteger) val2) < 0;\n\t\t}\n\t\tthrow new OrccRuntimeException(\"type mismatch in lt\");\n\t}", "protected boolean less(int i, int j)\n {\n return pq[i].compareTo(pq[j]) < 0;\n }", "public boolean lessThan(XObject obj2)\n throws javax.xml.transform.TransformerException{\n if(obj2.getType()==XObject.CLASS_NODESET)\n return obj2.greaterThan(this);\n return this.num()<obj2.num();\n }", "public void testComparatorChainOnMinvaluedCompatator() {\n ComparatorChain chain = new ComparatorChain();\r\n chain.addComparator(\r\n new Comparator() {\r\n public int compare(Object a, Object b) {\r\n int result = ((Comparable)a).compareTo(b);\r\n if(result < 0) {\r\n return Integer.MIN_VALUE;\r\n } else if(result > 0) {\r\n return Integer.MAX_VALUE;\r\n } else {\r\n return 0;\r\n }\r\n }\r\n }, true);\r\n\r\n assertTrue(chain.compare(new Integer(4), new Integer(5)) > 0); \r\n assertTrue(chain.compare(new Integer(5), new Integer(4)) < 0); \r\n assertTrue(chain.compare(new Integer(4), new Integer(4)) == 0); \r\n }", "boolean hasLt();", "public static BinaryExpression lessThanOrEqual(Expression expression0, Expression expression1, boolean liftToNull, Method method) { throw Extensions.todo(); }", "private static boolean less(Comparable[] pq, int i, int j) {\n return pq[i-1].compareTo(pq[j-1]) < 0;\n }", "public Snippet visit(LessThanEqualExpression n, Snippet argu) {\n\t\t Snippet _ret= new Snippet(\"\",\"\",null,false);\n\t\t Snippet f0 = n.identifier.accept(this, argu);\n\t\t n.nodeToken.accept(this, argu);\n\t\t Snippet f2 = n.identifier1.accept(this, argu);\n\t\t _ret.returnTemp = f0.returnTemp+\" <= \"+f2.returnTemp;\n\t return _ret;\n\t }", "public final BooleanDataValue lessThan(DataValueDescriptor left,\n\t\t\t\t\t\t\t DataValueDescriptor right)\n\t\t\t\t\t\t\t\tthrows StandardException\n\t{\n\t\tboolean isLessThan;\n\n\t\tif (left.isNull() || right.isNull())\n\t\t{\n\t\t\tisLessThan = false;\n\t\t}\n\t\telse\n\t\t{\t\n\t\t\tisLessThan = SQLBinary.compare(left.getBytes(), right.getBytes()) < 0;\n\t\t}\n\n\t\treturn SQLBoolean.truthValue(left,\n\t\t\t\t\t\t\t\t\t right,\n\t\t\t\t\t\t\t\t\t isLessThan);\n\t}", "public Snippet visit(LessThanExpression n, Snippet argu) {\n\t\t Snippet _ret= new Snippet(\"\",\"\",null,false);\n\t Snippet f0 = n.identifier.accept(this, argu);\n\t n.nodeToken.accept(this, argu);\n\t Snippet f2 = n.identifier1.accept(this, argu);\n\t _ret.returnTemp = f0.returnTemp+\" < \"+f2.returnTemp;\n\t return _ret;\n\t }", "public interface ComparableExpression<T> extends Expression<T> {\n /**\n * Method returning whether this expression is less than the other expression.\n *\n * @param expr Other expression\n * @return Whether this is less than the other\n */\n BooleanExpression lt(ComparableExpression<? extends T> expr);\n\n /**\n * Method returning whether this expression is less than the literal.\n *\n * @param t literal\n * @return Whether this is less than the other\n */\n BooleanExpression lt(T t);\n\n /**\n * Method returning whether this expression is less than or equal the other expression.\n *\n * @param expr Other expression\n * @return Whether this is less than or equal the other\n */\n BooleanExpression lteq(ComparableExpression<? extends T> expr);\n\n /**\n * Method returning whether this expression is less than or equal the literal.\n *\n * @param t literal\n * @return Whether this is less than or equal the other\n */\n BooleanExpression lteq(T t);\n\n /**\n * Method returning whether this expression is greater than the other expression.\n *\n * @param expr Other expression\n * @return Whether this is greater than the other\n */\n BooleanExpression gt(ComparableExpression<? extends T> expr);\n\n /**\n * Method returning whether this expression is greater than the literal.\n *\n * @param t literal\n * @return Whether this is greater than the other\n */\n BooleanExpression gt(T t);\n\n /**\n * Method returning whether this expression is greater than or equal the other expression.\n *\n * @param expr Other expression\n * @return Whether this is greater than or equal to the other\n */\n BooleanExpression gteq(ComparableExpression<? extends T> expr);\n\n /**\n * Method returning whether this expression is greater than or equal the literal.\n *\n * @param t literal\n * @return Whether this is greater than or equal to the other\n */\n BooleanExpression gteq(T t);\n\n /**\n * Method to return a numeric expression representing the aggregated minimum of this expression.\n *\n * @return expression for the minimum\n */\n ComparableExpression<T> min();\n\n /**\n * Method to return a numeric expression representing the aggregated maximum of this expression.\n *\n * @return expression for the maximum\n */\n ComparableExpression<T> max();\n\n /**\n * Method to return an order expression for this expression in ascending order.\n *\n * @return The order expression\n */\n OrderExpression<T> asc();\n\n /**\n * Method to return an order expression for this expression in descending order.\n *\n * @return The order expression\n */\n OrderExpression<T> desc();\n}", "public static boolean less_or_equal(String s1, String s2) {\n if (s1.compareTo(s2) >= 0) return true;\n //f.pln(\" Util::lessThan: s1 = \"+s1+\" s2 = \"+s2+\" rtn = \"+rtn);\n return false;\n }", "public final EObject ruleLessThanOperator() throws RecognitionException {\r\n EObject current = null;\r\n\r\n Token otherlv_1=null;\r\n\r\n enterRule(); \r\n \r\n try {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4705:28: ( ( () otherlv_1= '<' ) )\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4706:1: ( () otherlv_1= '<' )\r\n {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4706:1: ( () otherlv_1= '<' )\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4706:2: () otherlv_1= '<'\r\n {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4706:2: ()\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4707:5: \r\n {\r\n if ( state.backtracking==0 ) {\r\n\r\n current = forceCreateModelElement(\r\n grammarAccess.getLessThanOperatorAccess().getLessThanOperatorAction_0(),\r\n current);\r\n \r\n }\r\n\r\n }\r\n\r\n otherlv_1=(Token)match(input,62,FOLLOW_62_in_ruleLessThanOperator10473); if (state.failed) return current;\r\n if ( state.backtracking==0 ) {\r\n\r\n \tnewLeafNode(otherlv_1, grammarAccess.getLessThanOperatorAccess().getLessThanSignKeyword_1());\r\n \r\n }\r\n\r\n }\r\n\r\n\r\n }\r\n\r\n if ( state.backtracking==0 ) {\r\n leaveRule(); \r\n }\r\n }\r\n \r\n catch (RecognitionException re) { \r\n recover(input,re); \r\n appendSkippedTokens();\r\n } \r\n finally {\r\n }\r\n return current;\r\n }", "static BiPredicate<SibillaValue,SibillaValue> getRelationOperator(String op) {\n if (op.equals(\"<\")) { return (x,y) -> x.doubleOf()<y.doubleOf(); }\n if (op.equals(\"<=\")) { return (x,y) -> x.doubleOf()<=y.doubleOf(); }\n if (op.equals(\"==\")) { return (x,y) -> x.doubleOf()==y.doubleOf(); }\n if (op.equals(\"!=\")) { return (x,y) -> !x.equals(y); }\n if (op.equals(\">\")) { return (x,y) -> x.doubleOf()>y.doubleOf(); }\n if (op.equals(\">=\")) { return (x,y) -> x.doubleOf()>=y.doubleOf(); }\n return (x,y) -> false;\n }", "public final void mLESS() throws RecognitionException {\n\t\ttry {\n\t\t\tint _type = LESS;\n\t\t\tint _channel = DEFAULT_TOKEN_CHANNEL;\n\t\t\t// /Users/Sarah/Projects/ontop/obdalib-core/src/main/java/it/unibz/krdb/obda/parser/Datalog.g:437:5: ( '<' )\n\t\t\t// /Users/Sarah/Projects/ontop/obdalib-core/src/main/java/it/unibz/krdb/obda/parser/Datalog.g:437:16: '<'\n\t\t\t{\n\t\t\tmatch('<'); \n\t\t\t}\n\n\t\t\tstate.type = _type;\n\t\t\tstate.channel = _channel;\n\t\t}\n\t\tfinally {\n\t\t\t// do for sure before leaving\n\t\t}\n\t}", "@Override\n\tpublic Void visit(LessThan lt) {\n\t\tprintIndent(lt.token.getText());\n\t\tindent++;\n\t\tlt.left.accept(this);\n\t\tlt.right.accept(this);\n\t\tindent--;\n\t\treturn null;\n\t}", "BooleanExpression lteq(ComparableExpression<? extends T> expr);", "public final void mLESS() throws RecognitionException {\n try {\n int _type = LESS;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:11:6: ( '<' )\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:11:8: '<'\n {\n match('<'); \n\n }\n\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n }\n }", "public boolean isSmallerPrecedenceThan(/*const*/ Token T){\n\t\tassert(isOprUner() || isOprBiner());\n\t\tassert(T.isOprUner() || T.isOprBiner());\n\t\t\n\t\treturn getRank() < T.getRank();\n\t}", "Comparison createComparison();", "Comparison createComparison();", "@Override\n\tpublic Void visit(LessEqual le) {\n\t\tprintIndent(le.token.getText());\n\t\tindent++;\n\t\tle.left.accept(this);\n\t\tle.right.accept(this);\n\t\tindent--;\n\t\treturn null;\n\t}", "public boolean less( RandomAccessIterator iterator );", "public boolean lessP(Stella_Object y) {\n { Ratio x = this;\n\n { Ratio yRatio = ((Ratio)(x.coerceTo(y)));\n\n return ((x.numerator * yRatio.denominator) < (yRatio.numerator * x.denominator));\n }\n }\n }", "public final AstValidator.rel_op_lt_return rel_op_lt() throws RecognitionException {\n AstValidator.rel_op_lt_return retval = new AstValidator.rel_op_lt_return();\n retval.start = input.LT(1);\n\n\n CommonTree root_0 = null;\n\n CommonTree _first_0 = null;\n CommonTree _last = null;\n\n CommonTree set527=null;\n\n CommonTree set527_tree=null;\n\n try {\n // /home/hoang/DATA/WORKSPACE/trunk0408/src/org/apache/pig/parser/AstValidator.g:779:11: ( STR_OP_LT | NUM_OP_LT )\n // /home/hoang/DATA/WORKSPACE/trunk0408/src/org/apache/pig/parser/AstValidator.g:\n {\n root_0 = (CommonTree)adaptor.nil();\n\n\n _last = (CommonTree)input.LT(1);\n set527=(CommonTree)input.LT(1);\n\n if ( input.LA(1)==NUM_OP_LT||input.LA(1)==STR_OP_LT ) {\n input.consume();\n if ( state.backtracking==0 ) {\n set527_tree = (CommonTree)adaptor.dupNode(set527);\n\n\n adaptor.addChild(root_0, set527_tree);\n }\n\n state.errorRecovery=false;\n state.failed=false;\n }\n else {\n if (state.backtracking>0) {state.failed=true; return retval;}\n MismatchedSetException mse = new MismatchedSetException(null,input);\n throw mse;\n }\n\n if ( state.backtracking==0 ) {\n } \n\n }\n\n if ( state.backtracking==0 ) {\n\n retval.tree = (CommonTree)adaptor.rulePostProcessing(root_0);\n }\n\n }\n\n catch(RecognitionException re) {\n throw re;\n }\n\n finally {\n \t// do for sure before leaving\n }\n return retval;\n }", "final boolean isLessThan(final GbofId other){\r\n if (source_.is_less_than(other.source()) ) return true;\r\n if (other.source().is_less_than(source_)) return false;\r\n\r\n if (creation_ts_.isLessThan(other.creation_ts())) return true;\r\n if (creation_ts_.isGreaterThan(other.creation_ts())) return false;\r\n\r\n if (is_fragment_ && !other.is_fragment_) return true;\r\n if (!is_fragment_ && other.is_fragment_) return false;\r\n \r\n if (is_fragment_) {\r\n if (frag_length_ < other.frag_length_) return true;\r\n if (other.frag_length_ < frag_length_) return false;\r\n\r\n if (frag_offset_ < other.frag_offset_) return true;\r\n if (other.frag_offset_ < frag_offset_) return false;\r\n }\r\n\r\n return false; // all equal\r\n }", "private void createCmpOp(short op) {\n\t\tBranchInstruction if_icmplt_2 = InstructionFactory.createBranchInstruction(op, null);\n\t\til.append(if_icmplt_2);\n\t\til.append(new PUSH(cp, 1));\n\t\tBranchHandle append = il.append(InstructionFactory.createBranchInstruction(Constants.GOTO, null));\n\t\tInstructionHandle ih_7 = il.append(new PUSH(cp, 0));\n\t\tif_icmplt_2.setTarget(ih_7);\n\t\tInstructionHandle h = il.append(new NOP());\n\t\tappend.setTarget(h); \n\t}", "public void addLessThanFilter(@Nullable String fieldName, @Nullable Object value) {\n addFilter(fieldName, FilterOperator.LESS_THAN, value);\n }", "public T caseOperation_Less_Equals(Operation_Less_Equals object)\r\n {\r\n return null;\r\n }", "public boolean leftDistributive( Operator op){\n\t return false;\n }", "String lowValue(String comp) { return null; }", "BooleanExpression gt(ComparableExpression<? extends T> expr);", "public Character compop() {\n if (lexer.token != Symbol.LT && lexer.token != Symbol.GT && lexer.token != Symbol.EQUAL) {\n error.signal(\"Missing comparison operator for condition\");\n }\n Character c = lexer.getStringValue().toCharArray()[0];\n lexer.nextToken();\n return c;\n }", "private int handleIncomparablePrimitives(Object x, Object y) {\n int xCost = getPrimitiveValueCost(x);\n int yCost = getPrimitiveValueCost(y);\n int res = Integer.compare(xCost, yCost);\n return ascending ? res : -res;\n }", "public boolean lessThanOrEqual(XObject obj2)\n throws javax.xml.transform.TransformerException{\n if(obj2.getType()==XObject.CLASS_NODESET)\n return obj2.greaterThanOrEqual(this);\n return this.num()<=obj2.num();\n }", "public final void mLESS_OR_EQ1() throws RecognitionException {\n try {\n int _type = LESS_OR_EQ1;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:12:13: ( '<=' )\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:12:15: '<='\n {\n match(\"<=\"); \n\n\n }\n\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n }\n }", "public void testObjCompare()\n {\n assertEquals( Comparator.EQUAL, Util.objCompare(null,null) );\n assertEquals( Comparator.LESS, Util.objCompare(new Integer(10), new Integer(20)) );\n assertEquals( Comparator.GREATER, Util.objCompare(new Integer(25), new Integer(20)) );\n assertEquals( Comparator.UNDECIDABLE,Util.objCompare(null,new Integer(1)) );\n assertEquals( Comparator.UNDECIDABLE,Util.objCompare(new Integer(1),null) );\n }", "public final EObject ruleLessOrEqualThanOperator() throws RecognitionException {\r\n EObject current = null;\r\n\r\n Token otherlv_1=null;\r\n\r\n enterRule(); \r\n \r\n try {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4736:28: ( ( () otherlv_1= '<=' ) )\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4737:1: ( () otherlv_1= '<=' )\r\n {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4737:1: ( () otherlv_1= '<=' )\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4737:2: () otherlv_1= '<='\r\n {\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4737:2: ()\r\n // ../eu.artist.postmigration.nfrvt.lang.gml/src-gen/eu/artist/postmigration/nfrvt/lang/gml/parser/antlr/internal/InternalGML.g:4738:5: \r\n {\r\n if ( state.backtracking==0 ) {\r\n\r\n current = forceCreateModelElement(\r\n grammarAccess.getLessOrEqualThanOperatorAccess().getLessOrEqualThanOperatorAction_0(),\r\n current);\r\n \r\n }\r\n\r\n }\r\n\r\n otherlv_1=(Token)match(input,63,FOLLOW_63_in_ruleLessOrEqualThanOperator10565); if (state.failed) return current;\r\n if ( state.backtracking==0 ) {\r\n\r\n \tnewLeafNode(otherlv_1, grammarAccess.getLessOrEqualThanOperatorAccess().getLessThanSignEqualsSignKeyword_1());\r\n \r\n }\r\n\r\n }\r\n\r\n\r\n }\r\n\r\n if ( state.backtracking==0 ) {\r\n leaveRule(); \r\n }\r\n }\r\n \r\n catch (RecognitionException re) { \r\n recover(input,re); \r\n appendSkippedTokens();\r\n } \r\n finally {\r\n }\r\n return current;\r\n }", "default A isLessThan(Number number) {\n return satisfiesNumberCondition(new NumberCondition<>(number, LESS_THAN));\n }", "public TreeNode getLT()\r\n\t\t{\r\n\t\t\treturn lThan;\r\n\t\t}", "@Override\n public InterpreterValue smaller_equals(InterpreterValue v) {\n\n // If the given value is a IntegerValue then check if the value is smaller than\n // or equal to the own value and return a BooleanValue\n if(v instanceof IntegerValue) return BooleanValue.from(getValue() <= ((IntegerValue) v).getValue());\n\n // If the given value is a DoubleValue then check if the value is smaller than\n // or equal to the own value and return a BooleanValue\n if(v instanceof DoubleValue) return BooleanValue.from(getValue() <= ((DoubleValue) v).getValue());\n\n // In other case just throw an error\n throw new Error(\"Operator '<=' is not defined for type integer and \" + v.getName());\n\n }", "@Test\n public void defaultOperatorsEvaluteTrueTest() throws Exception {\n\n assertThat(getNode(\"1 == 1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 != 2\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 <> 2\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 < 2\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"2 > 1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 >= 1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"2 >= 1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 <= 2\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1 <= 1\", \"expr\").render(null), is((Object)true));\n\n // negative numbers\n assertThat(getNode(\"1 > -1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"-1 < 1\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"1.0 > -1.0\", \"expr\").render(null), is((Object)true));\n assertThat(getNode(\"-1.0 < 1.0\", \"expr\").render(null), is((Object)true));\n }", "public T caseOperation_Less(Operation_Less object)\r\n {\r\n return null;\r\n }", "private Term parseComparison(final boolean required) throws ParseException {\n Term t1 = parseBitwiseOr(required);\n while (t1 != null) {\n int tt = _tokenizer.next();\n if (tt == '<') {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.LtD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.LtI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.LtD(t1, t2);\n } else {\n reportTypeErrorN2(\"'<'\");\n }\n } else if (tt == '>') {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.GtD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.GtI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.GtD(t1, t2);\n } else {\n reportTypeErrorN2(\"'>'\");\n }\n } else if (isSpecial(\"==\")) {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.EqD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.EqI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.EqD(t1, t2);\n } else {\n reportTypeErrorN2(\"'=='\");\n }\n } else if (isSpecial(\"!=\")) {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.NEqD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.NEqI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.NEqD(t1, t2);\n } else {\n reportTypeErrorN2(\"'!='\");\n }\n } else if (isSpecial(\"<=\")) {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.LeD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.LeI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.LeD(t1, t2);\n } else {\n reportTypeErrorN2(\"'<='\");\n }\n } else if (isSpecial(\">=\")) {\n Term t2 = parseBitwiseOr(true);\n if (t1.isD() && t2.isN() || t1.isN() && t2.isD()) {\n t1 = new Term.GeD(t1, t2);\n } else if (t1.isI() && t2.isI()) {\n t1 = new Term.GeI(t1, t2);\n } else if (!isTypeChecking()) {\n t1 = new Term.GeD(t1, t2);\n } else {\n reportTypeErrorN2(\"'>='\");\n }\n } else {\n _tokenizer.pushBack();\n break;\n }\n }\n return t1;\n }", "@Test\n public void testCompareLess() {\n System.out.println(\"compare\");\n FileNameComparator instance = new FileNameComparator();\n int expResult = -1;\n int result = instance.compare(testFileA, testFileB);\n Assert.assertEquals(expResult, result);\n }", "public final boolean lessThan() {\n\n\t\tif (size > 1) {\n\n\t\t\tdouble topMostValue = pop();\n\t\t\tdouble secondTopMostValue = pop();\n\t\t\tif (secondTopMostValue < topMostValue) {\n\t\t\t\treturn true;\n\t\t\t}\n\t\t}\n\t\treturn false;\n\t}", "public boolean isOperator(){\n return true;\n }", "public final void mRULE_LESS_THAN() throws RecognitionException {\n try {\n int _type = RULE_LESS_THAN;\n int _channel = DEFAULT_TOKEN_CHANNEL;\n // ../org.sqlproc.meta/src-gen/org/sqlproc/meta/parser/antlr/internal/InternalProcessorMeta.g:12831:16: ( '<' )\n // ../org.sqlproc.meta/src-gen/org/sqlproc/meta/parser/antlr/internal/InternalProcessorMeta.g:12831:18: '<'\n {\n match('<'); \n\n }\n\n state.type = _type;\n state.channel = _channel;\n }\n finally {\n }\n }", "@Factory\n public static Matcher<QueryTreeNode> lessThan(Matcher<QueryTreeNode> leftMatcher, Matcher<QueryTreeNode> rightMatcher) {\n return relation(leftMatcher, \"<\", rightMatcher);\n }", "private boolean cond1(Data C) {\n return (C.getRight() < this.xL);\n }", "public Comparison compare(int left, int right) {\n int result = EQUAL;\n if (left < right) {\n result = LESS;\n } else if (left > right) {\n result = GREATER;\n }\n return checkResult(result);\n }", "static int compar(int d1,int m1, int y1,int d2,int m2, int y2 )\n{\n if(y1>y2)\n return 1;\n if(y1<y2)\n return -1;\n \n if(m1>m2)\n return 1;\n if(m1<m2)\n return -1;\n \n if(d1>d2)\n return 1;\n if(d1<d2)\n return -1;\n \n \n \n return 0;\n \n \n}", "boolean hasOperator();", "@Test \n public void compareFunctionalEquals() {\n HighScoreComparator comparator2 = new HighScoreComparator();\n int a;\n a = comparator2.compare(p1, p1);\n \n assertEquals(0, a);\n }", "public static BinaryExpression greaterThan(Expression expression0, Expression expression1) { throw Extensions.todo(); }", "public final void rule__OpCompare__Group_1__0__Impl() throws RecognitionException {\r\n\r\n \t\tint stackSize = keepStackSize();\r\n \t\r\n try {\r\n // InternalDroneScript.g:6699:1: ( ( '<' ) )\r\n // InternalDroneScript.g:6700:1: ( '<' )\r\n {\r\n // InternalDroneScript.g:6700:1: ( '<' )\r\n // InternalDroneScript.g:6701:2: '<'\r\n {\r\n if ( state.backtracking==0 ) {\r\n before(grammarAccess.getOpCompareAccess().getLessThanSignKeyword_1_0()); \r\n }\r\n match(input,27,FOLLOW_2); if (state.failed) return ;\r\n if ( state.backtracking==0 ) {\r\n after(grammarAccess.getOpCompareAccess().getLessThanSignKeyword_1_0()); \r\n }\r\n\r\n }\r\n\r\n\r\n }\r\n\r\n }\r\n catch (RecognitionException re) {\r\n reportError(re);\r\n recover(input,re);\r\n }\r\n finally {\r\n\r\n \trestoreStackSize(stackSize);\r\n\r\n }\r\n return ;\r\n }" ]
[ "0.7063472", "0.702036", "0.6923319", "0.68805414", "0.68475336", "0.67443454", "0.6729771", "0.67040974", "0.6693631", "0.6650627", "0.6650627", "0.6650627", "0.6626219", "0.65889764", "0.6575969", "0.6511729", "0.64547867", "0.63979536", "0.63849545", "0.638181", "0.6372783", "0.6342283", "0.63218874", "0.627199", "0.62666774", "0.6246653", "0.624217", "0.61998564", "0.61922306", "0.61517096", "0.6116319", "0.6115667", "0.611358", "0.6100281", "0.6095958", "0.60832137", "0.6063007", "0.6008638", "0.5998771", "0.59617406", "0.59525967", "0.5940704", "0.5928059", "0.59202605", "0.588996", "0.5884512", "0.5883458", "0.58606035", "0.5855101", "0.5841642", "0.58306694", "0.582945", "0.58266145", "0.5820782", "0.5808499", "0.5797036", "0.5789781", "0.5772908", "0.57702696", "0.5762565", "0.5754027", "0.5741967", "0.57309973", "0.570338", "0.57002735", "0.57002735", "0.56988764", "0.56941354", "0.567508", "0.56453663", "0.56411827", "0.563352", "0.5628038", "0.5622427", "0.5617957", "0.5611361", "0.5590279", "0.55784667", "0.5563806", "0.5547291", "0.55472326", "0.5544274", "0.55420935", "0.5541624", "0.55263585", "0.55180675", "0.55104136", "0.54952633", "0.5489835", "0.5485137", "0.5474123", "0.54728115", "0.546609", "0.5464879", "0.54533666", "0.5443965", "0.5436145", "0.5410379", "0.5406339", "0.53991544", "0.5386574" ]
0.0
-1
the parameter is discarded and set to 1 at the beginning
public int perform_GIS(int C) { // cerr << "C = " << C << endl; C = 1; // cerr << "performing AGIS" << endl; ArrayList<Double> pre_v = newArrayList(_vl.size(), 0.0); // jenia: same size as _vl's because later it can set _vl double pre_logl = -999999; for (int iter = 0; iter < 200; iter++) { double logl = update_model_expectation(); // fprintf(stderr, "iter = %2d C = %d f = %10.7f train_err = %7.5f", iter, C, logl, _train_error); if (_heldout.size() > 0) { // double hlogl = heldout_likelihood(); // fprintf(stderr, " heldout_logl(err) = %f (%6.4f)", hlogl, _heldout_error); } // cerr << endl; if (logl < pre_logl) { C += 1; _vl = pre_v; iter--; continue; } if (C > 1 && iter % 10 == 0) C--; pre_logl = logl; pre_v = _vl; // TODO jenia this doesn't have any effect assert (_vl.size() >= _fb.Size()); for (int i = 0; i < _fb.Size(); i++) { double coef = _vee.get(i) / _vme.get(i); plusEq(_vl, i, log(coef) / C); } } // cerr << endl; return 0; // jenia: the original didn't return anything explicitly }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setValue(int param1Int) {\n/* 294 */ this.s.setValue(-param1Int);\n/* */ }", "private static void setCounter() {++counter;}", "@Override\n public int retroceder() {\n return 0;\n }", "@Override \n\t\tprotected int getNumParam() {\n\t\t\treturn 1;\n\t\t}", "public void setOldCardinalityNum(int param){\n \n // setting primitive attribute tracker to true\n localOldCardinalityNumTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localOldCardinalityNum=param;\n \n\n }", "public void setNewCardinalityNum(int param){\n \n // setting primitive attribute tracker to true\n localNewCardinalityNumTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localNewCardinalityNum=param;\n \n\n }", "void incUsage() {\n incUsage(1);\n }", "public void aendereWert (int value) {\n\t\tvalue = 0 ;\n\t}", "public void setOneNewWanted () {\r\n numWanted ++;\r\n }", "public void setParam0(boolean param){\n \n // setting primitive attribute tracker to true\n \n if (false) {\n localParam0Tracker = false;\n \n } else {\n localParam0Tracker = true;\n }\n \n this.localParam0=param;\n \n\n }", "public final void setPendingCount(int paramInt)\n/* */ {\n/* 517 */ this.pending = paramInt;\n/* */ }", "void setArgument(int idx,int v) \t\t{ setArgument(idx,Integer.valueOf(v)); }", "public static void resetCount() {\n count = 1;\n }", "public void inc() {\n inc(1);\n }", "public void Increase()\n {\n Increase(1);\n }", "public void setResult(int param){\n \n // setting primitive attribute tracker to true\n \n if (param==java.lang.Integer.MIN_VALUE) {\n localResultTracker = false;\n \n } else {\n localResultTracker = true;\n }\n \n this.localResult=param;\n \n\n }", "public void add1() {\r\n value++;\r\n }", "public void setPassCounter()\r\n {\r\n passCounter++;\r\n\r\n }", "@Override\n public void execute(Frame frame) {\n frame.getOperandStack().pushInt(1);\n }", "public void setParam0(java.lang.String param){\n \n if (param != null){\n //update the setting tracker\n localParam0Tracker = true;\n } else {\n localParam0Tracker = true;\n \n }\n \n this.localParam0=param;\n \n\n }", "public void setParam0(java.lang.String param){\n \n if (param != null){\n //update the setting tracker\n localParam0Tracker = true;\n } else {\n localParam0Tracker = true;\n \n }\n \n this.localParam0=param;\n \n\n }", "public void setParam0(java.lang.String param){\n \n if (param != null){\n //update the setting tracker\n localParam0Tracker = true;\n } else {\n localParam0Tracker = true;\n \n }\n \n this.localParam0=param;\n \n\n }", "public void setParam0(java.lang.String param){\n \n if (param != null){\n //update the setting tracker\n localParam0Tracker = true;\n } else {\n localParam0Tracker = true;\n \n }\n \n this.localParam0=param;\n \n\n }", "public void set()\n\t{\n\t\tbitHolder.setValue(1);\n\t}", "public void IncrementCounter()\r\n {\r\n \tsetCurrentValue( currentValue.add(BigInteger.ONE)); \r\n \r\n log.debug(\"counter now: \" + currentValue.intValue() );\r\n \r\n }", "public boolean setModeParameter(long arg0) {\n\t\treturn false;\n\t}", "public void increment() {\n increment(1);\n }", "public void setArgs0(Facts param) {\r\n localArgs0Tracker = true;\r\n\r\n this.localArgs0 = param;\r\n\r\n\r\n }", "public void setArgs0(Facts param) {\r\n localArgs0Tracker = true;\r\n\r\n this.localArgs0 = param;\r\n\r\n\r\n }", "public void incCount() { }", "public void set_return(int param){\r\n \r\n // setting primitive attribute tracker to true\r\n local_returnTracker =\r\n param != java.lang.Integer.MIN_VALUE;\r\n \r\n this.local_return=param;\r\n \r\n\r\n }", "void setZeroStart();", "public void setFirstResult(int val) throws HibException;", "public abstract void setCntPrepaid(int cntPrepaid);", "private int iniFunc1(final int x) {\n return (x ^ (x >>> INITIALIZE_SHIFT)) * MAGIC_NUMBER1;\n }", "private static void increasePrimitive(int value) {\n value++;\n }", "public void set_count(int c);", "public void param_index_SET(short src)\n { set_bytes((short)(src) & -1L, 2, data, 2); }", "public int getPauseAfterSendOneParameter() \n {\n return 0;\n }", "void setValue(int value);", "public void increase() {\r\n\r\n\t\tincrease(1);\r\n\r\n\t}", "public void setFlags(int param1) {\n }", "public void setNumberOfArticulationParameters(short pNumberOfArticulationParameters)\n{ numberOfArticulationParameters = pNumberOfArticulationParameters;\n}", "public void increment(){\n value+=1;\n }", "default void inc(long value) {\n\t\tcount(Math.abs(value));\n\t}", "@Override\n public Integer reduceInit() { return 0; }", "public void resetRunCount() {\n\n }", "public void reset(){\n value = 0;\n }", "public void setNewCardinalityType(int param){\n \n // setting primitive attribute tracker to true\n localNewCardinalityTypeTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localNewCardinalityType=param;\n \n\n }", "boolean incLowValue() { return true; }", "private void incrementCounter()\r\n\t{\r\n\t\tthis.counter++;\r\n\t}", "private void incrPositiveCount(){\n m_PositiveCount++;\n }", "public static void\tset(IntPar par, int val)\n\t{ if (par != NULL) par.value = val; }", "public void setOldCardinalityType(int param){\n \n // setting primitive attribute tracker to true\n localOldCardinalityTypeTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localOldCardinalityType=param;\n \n\n }", "public void setValue(int value);", "public int setValue (int val);", "public IntPar(int val) { value = val; }", "private\tNum(int num) { value = num; }", "public int setParameter(int param, byte[] baValue) throws IllegalStateException\n {\n DsLog.log1(LOG_TAG, \"setParameter param:\" + param + \", baValue:\" + byteArrayToString(baValue));\n return audioEffect.setParameter(param, baValue);\n }", "public abstract int preN();", "public void setFirstResult(int begin) {\n\r\n\t}", "private static void calc1(int x) {\n\t\tx+=1;\n\t}", "@Override\n public void initialize() {\n counter = 0;\n }", "@Override\n public void initialize() {\n counter = 0;\n }", "public void setUnused(VersionVO param){\n \n if (param != null){\n //update the setting tracker\n localUnusedTracker = true;\n } else {\n localUnusedTracker = true;\n \n }\n \n this.localUnused=param;\n \n\n }", "public Builder setNum1(int value) {\r\n\t\t\t\tbitField0_ |= 0x00000002;\r\n\t\t\t\tnum1_ = value;\r\n\t\t\t\tonChanged();\r\n\t\t\t\treturn this;\r\n\t\t\t}", "public void set(int value)\n {\n set(value, true);\n }", "public void plum() {\n plum = true;\n }", "public void setinitialcounter() {\n\t\tmPref.edit().putInt(PREF_CONVERTED, 0).commit();\r\n\t}", "public void setFlag(Integer flag) { this.flag = flag; }", "public void setNop(int x){\n\t\t\tnop = x;\t\n\t\t}", "public void changeToBaseOne() {\r\n\t\tthis.numberBase = 1;\r\n\t}", "public void method_2244() {\r\n this.field_1858 = 0;\r\n }", "@Override\n public int continuar() {\n // TODO Auto-generated method stub\n return 0;\n }", "@Override\n\tpublic long getModeParameter() {\n\t\treturn 0;\n\t}", "void incrementCount();", "@Override\r\n\tpublic int getSecondArg() {\n\t\treturn 0;\r\n\t}", "@Override\n public int value() {\n return 0;\n }", "public void set_int(int param) {\n this.local_int = param;\n }", "public void incrementRefusals() {\n\t}", "public no(np paramnp)\r\n/* 13: */ {\r\n/* 14:30 */ this.b = paramnp;\r\n/* 15: */ }", "public void incCounter(){\n counter++;\n }", "@Override\r\n\tpublic int single() {\n\t\treturn 0;\r\n\t}", "@Override\n public int getNumberArguments() {\n return 1;\n }", "public abstract void setValue(int value);", "public void setPort(int param){\r\n \r\n // setting primitive attribute tracker to true\r\n localPortTracker =\r\n param != java.lang.Integer.MIN_VALUE;\r\n \r\n this.localPort=param;\r\n \r\n\r\n }", "public void setPort(int param){\r\n \r\n // setting primitive attribute tracker to true\r\n localPortTracker =\r\n param != java.lang.Integer.MIN_VALUE;\r\n \r\n this.localPort=param;\r\n \r\n\r\n }", "public void setA1(int a1)\n {\n this.a1 = a1;\n }", "public void setPreamp(int[] param) {\n validatePreamp(param);\n if (param != null) {\n localPreampTracker = true;\n } else {\n localPreampTracker = true;\n }\n this.localPreamp = param;\n }", "public void setId(int param){\r\n \r\n // setting primitive attribute tracker to true\r\n localIdTracker =\r\n param != java.lang.Integer.MIN_VALUE;\r\n \r\n this.localId=param;\r\n \r\n\r\n }", "private void setPositiveCount(int value) {\n m_PositiveCount = value;\n }", "public void addValue() {\n addValue(1);\n }", "private void set(){\n resetBuffer();\n }", "@Override\n\tpublic void one() {\n\t\t\n\t}", "public void reset() {\n next = 1000;\n }", "private void addParameter(int param) {\r\n command_parameters.addInt(param);\r\n }", "public static void primFormalParam(int num) //Line 10\r\n { //Line 11\r\n System.out.println(\"Line 12: In the method \"\r\n + \"primFormalParam, \"\r\n + \"before changing, num = \"\r\n + num); //Line 12\r\n\r\n num = 15; //Line 13\r\n\r\n System.out.println(\"Line 14: In the method \"\r\n + \"primFormalParam, \"\r\n + \"after changing, num = \"\r\n + num); //Line 14\r\n }", "void setCopies(short copies);", "protected void assignCurrentValue() {\n\t\tcurrentValue = new Integer(counter + incrValue);\n\t}", "private static void setValueInt(int value)\n {\n Util.valueInt = value;\n }", "void reset() {\n count = 0;\n\n }" ]
[ "0.64104825", "0.6315749", "0.62300605", "0.6203835", "0.6199114", "0.6194261", "0.6161371", "0.6160136", "0.60886186", "0.60626173", "0.60002035", "0.59685016", "0.5914385", "0.589373", "0.58845204", "0.5875221", "0.58455175", "0.5842475", "0.58384734", "0.58239526", "0.58239526", "0.58239526", "0.58239526", "0.57908994", "0.5788446", "0.5761964", "0.5743218", "0.5736306", "0.5736306", "0.5728063", "0.57193685", "0.57031494", "0.5702785", "0.5701398", "0.5677933", "0.56674784", "0.5662803", "0.56565756", "0.5652902", "0.5641976", "0.5641894", "0.5633251", "0.5628595", "0.5611569", "0.5598378", "0.5594161", "0.5585166", "0.5581298", "0.557716", "0.55682", "0.5567843", "0.5564991", "0.5564742", "0.5558572", "0.55559856", "0.5554968", "0.5539793", "0.5539298", "0.5532242", "0.5522679", "0.5519158", "0.55168396", "0.5516717", "0.5516717", "0.5514929", "0.5514307", "0.5504967", "0.5504466", "0.5500066", "0.5493486", "0.54919183", "0.5486741", "0.54795706", "0.547701", "0.54749405", "0.5473989", "0.54728234", "0.5463947", "0.5460934", "0.54524004", "0.54515505", "0.54466933", "0.5445403", "0.54414165", "0.54391754", "0.5439077", "0.5439077", "0.54357797", "0.5434689", "0.5434471", "0.5431792", "0.5431247", "0.54212064", "0.54208994", "0.54144084", "0.54137176", "0.54116845", "0.540471", "0.5404462", "0.54022074", "0.5401314" ]
0.0
-1
cerr << "performing LMVM" << endl;
public int perform_LMVM() { if (_inequality_width > 0) { int nvars = _fb.Size() * 2; double[] x = new double[nvars]; // INITIAL POINT for (int i = 0; i < nvars / 2; i++) { x[i] = _va.get(i); x[i + _fb.Size()] = _vb.get(i); } // int info = BLMVMSolve(x, nvars); for (int i = 0; i < nvars / 2; i++) { _va.set(i, x[i]); _vb.set(i, x[i + _fb.Size()]); _vl.set(i, _va.get(i) - _vb.get(i)); } return 0; } else { int nvars = _fb.Size(); double[] x = new double[nvars]; // INITIAL POINT for (int i = 0; i < nvars; i++) { x[i] = _vl.get(i); } // int info = BLMVMSolve(x, nvars); for (int i = 0; i < nvars; i++) { _vl.set(i, x[i]); } return 0; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void psvm() {\n\t\tSystem.out.println(\"test\");\r\n\t}", "public void helloVM()\n {\n \ttry {\n\n\t\t\t\n\t\t\tVirtualMachineConfigInfo vminfo = vm.getConfig();\n\t\t\tVirtualMachineCapability vmc = vm.getCapability();\n\t\t\tVirtualMachineRuntimeInfo vmri = vm.getRuntime();\n\t\t\tVirtualMachineSummary vmsum = vm.getSummary();\n\n\t\t\t\n\t\t\tSystem.out.println(\"------------------------------------------\");\n\t\t\tSystem.out.println(\"VM Information : \");\n\t\t\t\n\t\t\tSystem.out.println(\"VM Name: \" + vminfo.getName());\n\t\t\tSystem.out.println(\"VM OS: \" + vminfo.getGuestFullName());\n\t\t\tSystem.out.println(\"VM ID: \" + vminfo.getGuestId());\n\t\t\tSystem.out.println(\"VM Guest IP Address is \" +vm.getGuest().getIpAddress());\n\t\t\t\n\n\t\t\tSystem.out.println(\"------------------------------------------\");\n\t\t\tSystem.out.println(\"Resource Pool Informtion : \");\n\t\t\t\n\t\t\tSystem.out.println(\"Resource pool: \" +vm.getResourcePool());\n\t\t\t\n\t\t\tSystem.out.println(\"VM Parent: \" +vm.getParent());\n\t\t\t//System.out.println(\"VM Values: \" +vm.getValues());\n\t\t\tSystem.out.println(\"Multiple snapshot supported: \"\t+ vmc.isMultipleSnapshotsSupported());\n\t\t\tSystem.out.println(\"Powered Off snapshot supported: \"+vmc.isPoweredOffSnapshotsSupported());\n\t\t\tSystem.out.println(\"Connection State: \" + vmri.getConnectionState());\n\t\t\tSystem.out.println(\"Power State: \" + vmri.getPowerState());\n\t\t\t\n\n\t\t\t//CPU Statistics\n\n\t\t\tSystem.out.println(\"------------------------------------------\");\n\t\t\tSystem.out.println(\"CPU and Memory Statistics\" );\n\t\t\t\n\t\t\tSystem.out.println(\"CPU Usage: \" +vmsum.getQuickStats().getOverallCpuUsage());\n\t\t\tSystem.out.println(\"Max CPU Usage: \" + vmri.getMaxCpuUsage());\n\t\t\tSystem.out.println(\"Memory Usage: \"+vmsum.getQuickStats().getGuestMemoryUsage());\n\t\t\tSystem.out.println(\"Max Memory Usage: \" + vmri.getMaxMemoryUsage());\n\t\t\tSystem.out.println(\"------------------------------------------\");\n\n\t\t} catch (InvalidProperty e) {\n\t\t\te.printStackTrace();\n\t\t} catch (RuntimeFault e) {\n\t\t\te.printStackTrace();\n\t\t} catch (RemoteException e) {\n\t\t\te.printStackTrace();\n\t\t}\n }", "public void ex02() {\n\n boolean hasFinished = false;\n\n\n if (hasFinished==true) {\n printResults();\n }\n\n\n }", "static void jvisualvm() {\n\n }", "public void doPrimeObjective()\n {\n getLogger().info( \"hello from TerminalComponent\" );\n }", "void vorbereiten(){\n\t\tSystem.out.println(\"vorbereiten \");\n\t}", "public static void main(String[] args) {\n\t\tString solutionFile = \"dataset/vlc/task1_solution.en.clusterMle.txt\";\n//\t\tString queryFile = \"dataset/vlc/task1_query.en.f8.n5.txt\";\n//\t\tString targetFile = \"dataset/vlc/task1_target.en.f8.n5.txt\";\n//\t\tString linkFile = \"dataset/vlc/sim_0p_100n.csv\";\n\t\t\n\t\tString malletFile = \"dataset/vlc/folds/all.0.4189.mallet\";\n\t\tString queryFile = \"dataset/vlc/folds/query.0.csv\";\n\t\tString targetFile = \"dataset/vlc/folds/target.0.csv\";\n\t\tString linkFile = \"dataset/vlc/folds/trainingPairs.0.csv\";\n\t\t\n\t\tdouble alpha = 0.01, beta = 0.01, lambda = 0.01;\n\t\t\n\t\tMalletMleCluster clusterMle = new MalletMleCluster(malletFile, linkFile, alpha);\n\t\tTask1Solution solver = new Task1Solution(clusterMle);\n//\t\tfor(alpha = 0.1; alpha<1; alpha += 0.2) {\n//\t\t\tfor(beta = 0.1; beta<1; beta += 0.2) {\n\t\t\t\tfor (lambda = 0.1; lambda<1; lambda += 0.05) {\n\t\t\tclusterMle.setSmoothParameters(alpha, beta, lambda);\n//\t\t\tclusterMle.retrieveTask1Solution(queryFile, solutionFile);\n\t\t\ttry {\n\t\t\t\tsolver.retrieveTask1Solution(queryFile, solutionFile);\n\t\t\t\tdouble precision = Task1Solution.evaluateResult(targetFile, solutionFile);\n\t\t\t\tSystem.out.println(\"alpha: \" + alpha + \"beta: \" + beta + \n\t\t\t\t\t\t\", Lambda: \" + lambda + \", Mle precision: \" + precision);\n\t\t\t} catch (Exception e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\t\t}\n//\t\t\t}\n//\t\t}\n\t}", "void printMST();", "public abstract void execute(VirtualMachine vm);", "public void selfTest() {\n \n \n \n /**\n * TESTING CONFIGURATION RIGHT HERE:\n */\n int total = 1; //How many tests should we run\n int start = 0; //The first test to run\n //TestStubs.storePrints(); //store prints until the end\n TestStubs.displayDebugWhileTesting(false); //shows all the debug prints (with context switches) if set to true\n \n \n //MemoryMap.selfTest();\n //Swap.selfTest();\n \n UserProcess.testing = true;\n TestStubs.debugPrint(\"SELF TESTING VMKERNEL!\");\n \n int passed = 0;\n \n for (int i = 0; i < total; i++) {\n if (runTest(i+start))\n passed += 1;\n }\n \n if (passed != total) {\n TestStubs.debugPrint(\"SOME TESTS FAILED! \" + passed + \"/\" + total + \" passed.\");\n } else {\n TestStubs.debugPrint(\"ALL TESTS PASSED! \" + passed + \"/\" + total + \" passed.\");\n }\n \n UserProcess.testing = false;\n \n\n \n //System.out.println(TestStubs.getStoredPrints());\n //TestStubs.clearAndDontStorePrints();\n \n if (passed != total) {\n System.out.flush();\n /// kernel.terminate();\n }\n \n TestStubs.disable();\n \n }", "private static void FinalIndVsPAk() {\n\t\tSystem.out.println(\"Pak Lost The Match\");\n\t\t\n\t}", "public void testSVMChunkLearnng() throws IOException, GateException {\n // Initialisation\n System.out.print(\"Testing the SVM with liner kernenl on chunk learning...\");\n File chunklearningHome = new File(new File(learningHome, \"test\"),\n \"chunklearning\");\n String configFileURL = new File(chunklearningHome, \"engines-svm.xml\")\n .getAbsolutePath();\n String corpusDirName = new File(chunklearningHome, \"data-ontonews\")\n .getAbsolutePath();\n //Remove the label list file, feature list file and chunk length files.\n String wdResults = new File(chunklearningHome,\n ConstantParameters.SUBDIRFORRESULTS).getAbsolutePath();\n emptySavedFiles(wdResults);\n String inputASN = \"Key\";\n loadSettings(configFileURL, corpusDirName, inputASN, inputASN);\n // Set the evaluation mode\n RunMode runM=RunMode.EVALUATION;\n learningApi.setLearningMode(runM);\n controller.execute();\n // Using the evaluation mode for testing\n EvaluationBasedOnDocs evaluation = learningApi.getEvaluation();\n // Compare the overall results with the correct numbers\n assertEquals(\"Wrong value for correct: \", 44, (int)Math.floor(evaluation.macroMeasuresOfResults.correct));\n assertEquals(\"Wrong value for partial: \", 10, (int)Math.floor(evaluation.macroMeasuresOfResults.partialCor));\n assertEquals(\"Wrong value for spurious: \", 11, (int)Math.floor(evaluation.macroMeasuresOfResults.spurious));\n assertEquals(\"Wrong value for missing: \", 40, (int)Math.floor(evaluation.macroMeasuresOfResults.missing));\n\n System.out.println(\"completed\");\n // Remove the resources\n clearOneTest();\n }", "@SuppressWarnings(\"deprecation\")\n\t\n\tpublic void run() {\n\t\t\n\t\n\t\n\t\tvmCursor = vmsetting.find();\n\t\tclusterCursor = cluster.find();\n\t\tif(!vmCursor.toArray().toString().equals(cachedvm.toArray().toString())\n\t\t\t\t||!clusterCursor.toArray().toString().equals(cachedcluster.toArray().toString()))\n\t\t{\n\t\t\tSystem.out.println(\"cachedvm \"+ cachedvm.toArray());\n\t\t\tSystem.out.println(\"vmcursor \"+ vmCursor.toArray());\n\t\t\tSystem.out.println(\"cachedcluster \"+ cachedcluster.toArray());\n\t\t\tSystem.out.println(\"clustercursor \"+ clusterCursor.toArray());\n\t\t\t\n\t\t\t\n\t\t\tcachedvm = vmCursor;\n\t\t\tcachedcluster = clusterCursor;\n\t\t\tflag0=\"false\";\n\t\t\tflag1=\"false\";\n\t\t}\n\t\n\t\tif(flag0==\"false\"){\n\t\tif(vmsetting.find().hasNext())\n\t\t{\n\t\t\tlogger.info(\"VM Setting is not null, config file exported to path \"+exppath1+ \".\");\n\t\t\ttry {\n\t\t\t\tSystem.out.println(shellExecuter1.executeFile(expcmd11));\n\t\t\t\tSystem.out.println(shellExecuter1.executeFile(expcmd1));\n\t\t\t\tflag0 = \"true\";\n\t\t\t} catch (Exception e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\n\t\t}\n\t\telse {\n\t\t\tlogger.info(\"VM Setting is null.\");\n\t\t}\n\t\t}\n\t\t\n\t\tif(flag1==\"false\"){\n\t\tif(cluster.find().hasNext())\n\t\t{\n\t\t\tlogger.info(\"Cluster Setting is not null, config file exported to path \"+exppath1+ \".\");\n\t\t\ttry {\n\t\t\t\tSystem.out.println(shellExecuter1.executeFile(expcmd22));\n\t\t\t\tSystem.out.println(shellExecuter1.executeFile(expcmd2));\n\t\t\t\tflag1 = \"true\";\n\t\t\t\tlogger.info(\"Config export completed\");\n\t\t\t\n\t\t\t} catch (Exception e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\n\t\t\n\t\t}\n\t\telse {\n\t\t\tlogger.info(\"Cluster Setting is null.\");\n\t\t}\n\t\t\n\t\n\t\tif(flag0==\"ture\"&&flag1==\"true\")\n\t\t\tThread.currentThread().stop();\n\t\t\t\n\t\t}\n\t}", "public void displayResults() {\r\n Preferences.debug(\" ******* FitMultiExponential ********* \\n\\n\", Preferences.DEBUG_ALGORITHM);\r\n dumpTestResults();\r\n }", "public static void main(String[] args) {\n\t\t\n\t\tmm\n\t\t\n\t}", "void emi(){\n\t\tSystem.out.println(\"This is HomeLoan EMi\");\n\t}", "private void syso() {\nSystem.out();\r\n}", "public void printMsg() {\n System.out.println(\"This is an example RMI program\");\n }", "public void printFailure() {\n //\n }", "public void reset() \n {\n try \n {\n // your code here\n \tSystem.out.println(\"Resetting virtual machine '\"+vm.getName() +\"'. Please wait...\"); \n \tTask t=vm.resetVM_Task();\n \tif(t.waitForTask()== Task.SUCCESS)\n \t{\n\t \tSystem.out.println(\"Virtual machine reset.\");\n\t \tSystem.out.println(\"====================================\");\n \t}\n \telse\n \t\tSystem.out.println(\"Reset failed...\");\n } \n catch ( Exception e ) \n { \n \tSystem.out.println( e.toString() ) ; \n }\n }", "@Override\n\tpublic void run() {\n\t\tfileName = \"out_\" + Program.getProgram().getFileName() + \"_\";\n\t\tint numAddStop = 0;\n\t\t//fileName = \"out_themida_\";\n\n\t\t//fileState.clearContentFile();\n\t\t//bkFile.clearContentFile();\n\t\toverallStartTime = System.currentTimeMillis();\n\t\tlong overallStartTemp = overallStartTime;\n\t\t// BE-PUM algorithm\n\t\tSystem.out.println(\"Starting On-the-fly Model Generation algorithm.\");\n\t\tprogram.getResultFileTemp().appendInLine('\\n' + program.getFileName() + '\\t');\n\t\t\n\t\t// Set up initial context\n\t\tX86TransitionRule rule = new X86TransitionRule();\n\t\tBPCFG cfg = Program.getProgram().getBPCFG();\n\t\tEnvironment env = new Environment();\n\t\t//env.getMemory().resetImportTable(program);\n\t\tAbsoluteAddress location = Program.getProgram().getEntryPoint();\n\t\tInstruction inst = Program.getProgram().getInstruction(location, env);\n\t\tList<BPPath> pathList = new ArrayList<BPPath>();\n\t\t\n\t\t// Insert start node\n\t\tBPVertex startNode = null;\n\t\tstartNode = new BPVertex(location, inst);\n\t\tstartNode.setType(0);\n\t\tcfg.insertVertex(startNode);\n\n\t\tBPState curState = null;\n\t\tBPPath path = null;\n\t\tcurState = new BPState(env, location, inst);\n\t\tpath = new BPPath(curState, new PathList(), new Formulas());\n\t\tpath.setCurrentState(curState);\n\t\tpathList.add(path);\n\n\t\t/*if (Program.getProgram().getFileName().equals(\"api_test_v2.3_lvl1.exe\") \n\t\t\t\t&& isRestored) {\n\t\t\tSystem.out.println(\"Restore State from File.\");\n\t\t\tFileProcess reFile = new FileProcess(\"data/data/restoreState.txt\");\n\t\t\tpathList = restoreState(reFile);\n\t\t\t// bkFile.clearContentFile();\n\t\t\tSystem.out.println(\"Finished restoring state!\");\n\t\t}*/\n\n\t\t// Update at first -----------------------------\n\t\tTIB.setBeUpdated(true);\n\t\tTIB.updateTIB(curState);\n\t\t// ---------------------------------------------\n\n\t\t// PHONG - 20150801 /////////////////////////////\n\t\t// Packer Detection via Header\n\t\tSystem.out.println(\"================PACKER DETECTION VIA HEADER ======================\");\n\t\tif (OTFModelGeneration.detectPacker)\n\t\t{\n\t\t\tprogram.getDetection().detectViaHeader(program);\n\t\t\tprogram.getDetection().setToLogFirst(program);\n\t\t}\n\t\tSystem.out.println(\"==================================================================\");\n\t\t/////////////////////////////////////////////////\n\t\t\n\t\tsynchronized (OTFThreadManager.getInstance()) {\n\t\t\ttry {\n\t\t\t\tOTFThreadManager.getInstance().check(this, pathList);\n\t\t\t\tOTFThreadManager.getInstance().wait();\n\t\t\t} catch (Exception e) {\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}\n\t\t// PHONG - 20150724\n\t\tSystem.out.println(\"================PACKER DETECTION VIA OTF======================\");\n\t\tprogram.getDetection().packedByTechniques();\n\t\tprogram.getDetection().packedByTechniquesFrequency();\n\t\tSystem.out.println(\"==============================================================\");\n\t}", "default void run() {\n\t\tSystem.out.println(\"run\");\r\n\t}", "public static void printVMinfo(VirtualMachine vm) throws IOException, InterruptedException{\n\t\t\t\n\t\t\t\tvm.getResourcePool();\n\t\t\t\tSystem.out.println(\"Hello \" + vm.getName());\n\t\t\t\tSystem.out.println(\"Status \" + vm.getGuestHeartbeatStatus());\n\t\t\t\tSystem.out.println(\"get ip \"+ vm.getSummary().getGuest().getIpAddress());\n\t\t\t\tSystem.out.println(\"get id \"+ vm.getSummary().getGuest().getGuestId());\n\t\t\t\tSystem.out.println(\"get toolstatus \"+ vm.getSummary().getGuest().toolsRunningStatus);\n\t\t\t\tSystem.out.println(\"get hostname \"+ vm.getSummary().getGuest().getHostName());\n\t\t\t\tSystem.out.println(\"GuestOS: \" + vm.getConfig().getGuestFullName());\n\t\t\t\tSystem.out.println(\"vm version: \" + vm.getConfig().version);\n\t\t\t\tSystem.out.println(\"meomery: \" + vm.getConfig().getHardware().memoryMB + \"MB\");\n\t\t\t\t//System.out.println(\"meomery overhead: \" + vm.getConfig().memoryAllocation.reservation.toString() + \"MB\");\n\t\t\t\tSystem.out.println(\"cpu: \" + vm.getConfig().getHardware().numCPU);\n\t\t\t\tSystem.out.println(\"Multiple snapshot supported: \" + vm.getCapability().isMultipleSnapshotsSupported());\n\t\t\t\tSystem.out.println(\"====================================================================\");\n\t\t\t}", "private void sysout() {\nSystem.out.println(\"pandiya\");\n}", "protected void executeVmCommand() {\n }", "public void InitLinearLV() throws Exception{\n\tcommandExec c1 = new commandExec();\n\tc1.runCommand(\"lvcreate -n LinearLV -l 50%VG /dev/TargetVG\" );\n}", "@Override\r\n\tpublic void work() {\n\t\tSystem.out.println(\"0.5 FTE\");\r\n\t}", "@Override\n\tpublic void m() {\n\t\tSystem.out.println(\"m\");\n\t\t\n\t}", "protected void execute() {\n\t\tSystem.out.println(\"Vision error: \" + RobotMap.VisionDistanceLeftPIDController.getError() + \" , \" + RobotMap.VisionDistanceRightPIDController.getError());\n\t\tSystem.out.println(\"vision, pidcontroller output: \" + RobotMap.VisionDistanceLeftPIDController.get() + \" , \" + RobotMap.VisionDistanceRightPIDController.get());\n\n\t}", "VM createVM();", "public boolean compute() throws Exception{\n \n String cmdLine;\n String voicedir = db.getProp(db.ROOTDIR);\n \n /* Run: perl hts/scripts/Training.pl hts/scripts/Config.pm (It can take several hours...)*/ \n cmdLine = db.getExternal(db.PERLPATH) + \"/perl \" + voicedir +\"hts/scripts/Training.pl \" + voicedir + \"hts/scripts/Config.pm\"; \n launchProcWithLogFile(cmdLine, \"\", voicedir);\n \n return true;\n }", "@Override\r\n public void run() {\n System.out.println(\"Running in Java (regular algorithm)\");\r\n }", "@Override\n\tpublic void statusVomMenschen() {\n\t\tSystem.out.println(\"Sie wurden getroffen nun können Sie nicht mehr so schnell laufen!\");\n\t}", "public void powerOn() \n {\n try \n {\n // your code here\n \tSystem.out.println(\"Powering on virtual machine '\"+vm.getName() +\"'. Please wait...\"); \n \tTask t=vm.powerOnVM_Task(null);\n \tif(t.waitForTask()== Task.SUCCESS)\n \t{\n\t \tSystem.out.println(\"Virtual machine powered on.\");\n\t \tSystem.out.println(\"====================================\");\n \t}\n \telse\n \t\tSystem.out.println(\"Power on failed / VM already powered on...\");\n } \n catch ( Exception e ) \n { \n \tSystem.out.println( e.toString() ) ;\n }\n }", "@Override\r\n\t\tvoid m() {\n\t\t\tSystem.out.println(\"m\");\r\n\t\t}", "public void run() throws Exception {\n try {\n\t System.out.println(\"SSVD start!\");\n FileSystem fs = FileSystem.get(conf);\n\n Path qPath = new Path(outputPath, \"Q-job\");\n Path btPath = new Path(outputPath, \"Bt-job\");\n Path yPath = new Path(outputPath, \"Y-job\"); //tetst phase\n Path uHatPath = new Path(outputPath, \"UHat\");\n Path svPath = new Path(outputPath, \"Sigma\");\n Path uPath = new Path(outputPath, \"U\");\n Path vPath = new Path(outputPath, \"V\");\n\n if (overwrite) {\n fs.delete(outputPath, true);\n }\n\n\t int[] iseed = {0,0,0,1};\n\t double[] x = new double[1];\n\t Dlarnv.dlarnv(2,iseed,0,1,x,0);\n\t long seed = (long)(x[0]*(double)Long.MAX_VALUE);\n\n\t long start, end;\n\t \t\t\n\tstart = new Date().getTime();\n\tQJob.run(conf,\n inputPath,\n qPath.toString(),\n\t\treduceSchedule,\n k,\n p,\n seed,\n\t\tmis);\n\tend = new Date().getTime();\n\tSystem.out.println(\"Q-Job done \"+Long.toString(end-start));\n\tLogger LOG = LoggerFactory.getLogger(SSVDSolver.class);\n\t \n /*\n * restrict number of reducers to a reasonable number so we don't have to\n * run too many additions in the frontend when reconstructing BBt for the\n * last B' and BB' computations. The user may not realize that and gives a\n * bit too many (I would be happy i that were ever the case though).\n */\n\t \n start = new Date().getTime();\n\t BtJob.run(conf,\n inputPath,\n\t\t\t\tbtPath,\n\t\t\t\tqPath.toString(),\n\t\t\t\tk,\n p,\n outerBlockHeight,\n\t\t\t\tq <= 0 ? Math.min(1000, reduceTasks) : reduceTasks,\n\t\t\t\tq <= 0,\n\t\t\t\treduceSchedule,\n\t\t\t\tmis);\n\n\t end = new Date().getTime();\n System.out.println(\"Bt-Job done \"+Long.toString(end-start));\n\t \n // power iterations is unnecessary in application of recommendation system \t \n\t /*for (int i = 0; i < q; i++) {\n\t Path btPathGlob = new Path(btPath, BtJob.OUTPUT_BT + \"-*\");\n\t\tPath aBtPath = new Path(outputPath, String.format(\"ABt-job-%d\", i + 1)); \n qPath = new Path(outputPath, String.format(\"ABtQ-job-%d\", i + 1));\t\t\n ABtDenseOutJob.run(conf,\n inputPath,\n btPathGlob,\n aBtPath,//qPath,\n //ablockRows,\n //minSplitSize,\n k,\n p,\n //abtBlockHeight,\n reduceTasks,\n //broadcast\n\t\t\t\t\t\t mis);\n\t\t\n\t\tToolRunner.run(conf, new QRFirstJob(), new String[]{\n \"-input\", aBtPath.toString(),\n \"-output\", qPath.toString(),\n\t\t\t \"-mis\",Integer.toString(mis),\n\t\t\t \"-colsize\", Integer.toString(k+p),\n \"-reduceSchedule\", reduceSchedule});\n\t\t\t \n btPath = new Path(outputPath, String.format(\"Bt-job-%d\", i + 1));\n\n BtJob.run(conf,\n inputPath,\n\t\t\t\t btPath,\n qPath.toString(), \n k,\n p,\n outerBlockHeight,\n i == q - 1 ? Math.min(1000, reduceTasks) : reduceTasks,\n i == q - 1,\n\t\t\t\t reduceSchedule,\n\t\t\t\t mis);\n }*/\n\t \n cmUpperTriangDenseMatrix bbt =\n loadAndSumUpperTriangMatrices(fs, new Path(btPath, BtJob.OUTPUT_BBT\n + \"-*\"), conf);\n\n // convert bbt to something our eigensolver could understand\n assert bbt.numColumns() == k + p;\n\n double[][] bbtSquare = new double[k + p][];\n for (int i = 0; i < k + p; i++) {\n bbtSquare[i] = new double[k + p];\n }\n\n for (int i = 0; i < k + p; i++) {\n for (int j = i; j < k + p; j++) {\n bbtSquare[i][j] = bbtSquare[j][i] = bbt.get(i, j);\n }\n }\n\n svalues = new double[k + p];\n\n // try something else.\n EigenSolver eigenWrapper = new EigenSolver(bbtSquare);\n double[] eigenva2 = eigenWrapper.getWR();\n\t \n for (int i = 0; i < k + p; i++) {\n svalues[i] = Math.sqrt(eigenva2[i]); // sqrt?\n }\n // save/redistribute UHat\n double[][] uHat = eigenWrapper.getVL();\n\t //double[][] uHat = eigenWrapper.getUHat();\n\t \n fs.mkdirs(uHatPath);\n SequenceFile.Writer uHatWriter =\n SequenceFile.createWriter(fs,\n conf,\n uHatPath = new Path(uHatPath, \"uhat.seq\"),\n IntWritable.class,\n VectorWritable.class,\n CompressionType.BLOCK);\n\t \n int m = uHat.length;\n IntWritable iw = new IntWritable();\n VectorWritable vw = new VectorWritable();\n\t \n for (int i = 0; i < m; i++) {\n vw.set(new DenseVector(uHat[i],true));\n iw.set(i);\n uHatWriter.append(iw, vw);\n }\n\t uHatWriter.close();\n\n SequenceFile.Writer svWriter =\n SequenceFile.createWriter(fs,\n conf,\n svPath = new Path(svPath, \"svalues.seq\"),\n IntWritable.class,\n VectorWritable.class,\n CompressionType.BLOCK);\n\n vw.set(new DenseVector(svalues, true));\n svWriter.append(iw, vw);\n\n svWriter.close();\n\n\t start = new Date().getTime();\n UJob ujob = null;\t \n if (computeU) {\n ujob = new UJob();\n\t\tujob.start(conf,\n new Path(btPath, BtJob.Q_MAT+ \"-*\"),\n uHatPath,\n svPath,\n uPath,\n k,\n cUHalfSigma,\n\t\t\t\t mis);\t\t\t\t \n // actually this is map-only job anyway\n }\n\n VJob vjob = null;\n if (computeV) {\n vjob = new VJob();\n vjob.start(conf,\n new Path(btPath, BtJob.OUTPUT_BT + \"-*\"),\n uHatPath,\n svPath,\n vPath,\n k,\n reduceTasks,\n\t\t\t\t subRowSize,\n cVHalfSigma,\n\t\t\t\t mis);\n }\n\n if (ujob != null) {\n ujob.waitForCompletion();\n this.uPath = uPath.toString();\n }\n\t System.out.println(\"U-Job done \");\n\t \n if (vjob != null) {\n vjob.waitForCompletion();\n this.vPath = vPath.toString();\n }\n\tend = new Date().getTime();\n\tSystem.out.println(\"U-Job+V-Job done \"+(end-start));\n\t\n } catch (InterruptedException exc) {\n throw new IOException(\"Interrupted\", exc);\n } catch (ClassNotFoundException exc) {\n throw new IOException(exc);\n }\n\n }", "public void test() {\n\t\t\r\n\t\tSystem.out.println(\"-->\" + CommonMethod.createCmdOfflineVersion10(\"jxsmarthome\"));\r\n\t\t\r\n\t}", "public void execute(OutputManager om) {\n int voxelNumber = 0;\n while (CL_Initializer.data.more())\n try {\n \n double[] nextVoxel = CL_Initializer.data.nextVoxel();\n double[] nextGradAdj = {};\n if (CL_Initializer.gradAdj!= null) {\n nextGradAdj = CL_Initializer.gradAdj.nextVoxel();\n }\n\n // Fit or output background default.\n double backgroundB0 = CL_Initializer.imPars\n .geoMeanZeroMeas(nextVoxel);\n boolean bg = isBG(backgroundB0);\n if (bg) {\n int ipv = 0;\n int vps = 0;\n if (CL_Initializer.compartmentModel) {\n ipv = fitter.getNumValuesPerRun();\n vps = fitter.getNumValuesPerSolution();\n }\n else {\n ipv = inv.itemsPerVoxel();\n vps = ipv;\n }\n\n double[] voxOut = new double[ipv];\n \n for(int i=0; i<ipv; i=i+vps) {\n\n \t// Set the exitcode to -1 to indicate background.\n \tvoxOut[i] = -1;\n \n \tif (backgroundB0 > 0.0) {\n \t\tvoxOut[i+1] = Math.log(backgroundB0);\n \t} else {\n \t\tvoxOut[i+1] = 0.0;\n \t}\n }\n\t\n om.output(voxOut);\n \n // The inverter may have other operations to perform\n // in background voxels.\n if (!CL_Initializer.compartmentModel)\n inv.background();\n \n } else try {\n // Fit the model and output the result.\n if (CL_Initializer.compartmentModel) {\n double[][] fit;\n if (CL_Initializer.gradAdj!=null) {\n fit = fitter.fit(nextVoxel, nextGradAdj);\n }\n else {\n fit = fitter.fit(nextVoxel);\n }\n for (int i = 0; i < fit.length; i++) {\n om.output(fit[i]);\n }\n }\n \n else {\n\n double[] fittedData;\n if (CL_Initializer.gradAdj!=null) {\n fittedData = inv.invert(nextVoxel, nextGradAdj);\n }\n else {\n fittedData = inv.invert(nextVoxel);\n }\n\n om.output(fittedData);\n\n }\n\n } catch (MinimizerException e) {\n\n throw new LoggedException(e);\n\n }\n\n logger.fine(\"Completed voxel: \" + voxelNumber + \" \" + bg);\n\n voxelNumber++;\n \n } catch (DataSourceException e) {\n throw new LoggedException(\"The data file does not contain a whole number of voxels. Check the scheme file. Got Exception \" + e);\n }\n \n // Output statistics compiled by the inverter.\n if (!CL_Initializer.compartmentModel)\n inv.close();\n \n // Flush output\n om.close();\n \n }", "public static void Result(Matriks M, int flag) { \r\n\t\tint n = M.KolEff;\r\n \tSystem.out.print(\"Hasilnya adalah: \"); \r\n \r\n \tif (flag == 2){ \r\n \t\tSystem.out.println(\"Solusi banyak\");\r\n \t} \r\n \telse if (flag == 3){ \r\n \t\tSystem.out.println(\"Tidak memiliki solusi\"); \r\n \t}\r\n \telse { \r\n \tfor (int i = 0; i < n; i++) \r\n \tSystem.out.print(M.Elmt[i][n] / M.Elmt[i][i] + \" \"); \r\n \t} \r\n\t}", "public void run() {\n\t\tfor(int i = 0; i < 100; i++) {\n\t\t\t// E step\n\t\t\tsigma = calculateNewSigma();\n\t\t\t// M step\n\t\t\tu = calculateNewU();\n\t\t\t//System.out.println(\"u= \"+u+\"; sigma= \"+sigma);\n\t\t\t\n\t\t}\n\t\tSystem.out.println(\"u= \"+u+\"; sigma= \"+sigma);\n\t}", "public static void main(String args[]) throws Exception\r\n\t{\n \tSystem.out.print(\"TASK 2\");\r\n \t\r\n\t}", "private static void err(String msg) {\n System.err.println(PerfCakeAgent.class.getSimpleName() + \" > ERROR: \" + msg);\n }", "void log() {\n\t\tm_drivetrain.log();\n\t\tm_forklift.log();\n\t}", "@Override\n public void run() {\n startVMS(mStrVMID, mParams);\n }", "void printUsage(){\n\t\tSystem.out.println(\"Usage: RefactorCalculator [prettyPrint.tsv] [tokenfile.ccfxprep] [cloneM.tsv] [lineM.tsv]\");\n\t\tSystem.out.println(\"Type -h for help.\");\n\t\tSystem.exit(1); //error\n\t}", "final private static void usage () {\n\t\t usage_print () ;\n\t\t System.exit (0) ;\n }", "public void runProgram() {\n\t\tJTextPane code = ((MinLFile) tabbedPane.getSelectedComponent()).CodeArea;\n\t\tminc.consolearea.setText(\"\");\n\t\tinterpretorMainMethod(code.getText(), 0);\n\t\tdouble_variables.clear();\n\t\tstring_variables.clear();\n\t\tfunctions.clear();\n\t}", "public void Makan()\n\t{\n\tSystem.out.println(\"Harimau Makan Daging dan minum susu\");\n\tSystem.out.println();\n\t}", "public static void main()\n {\n Lex edp = new Lex();\n try\n {\n edp.run();\n } catch (Exception e)\n {\n System.out.println(\"Exception: \" + e.toString());\n e.printStackTrace();\n } // catch\n }", "private void doResearch() {\n\t\tSystem.out.println(\"Students must do research\");\n\t}", "public void printVirtualMachines() throws InvalidProperty, RuntimeFault, RemoteException{\r\n\t\tManagedEntity[] mes = new\r\n\t\t\t\tInventoryNavigator(_instance.getRootFolder()).searchManagedEntities(\"VirtualMachine\");\r\n\t\tfor (int i = 0; i < mes.length; i++) {\r\n\t\t\tVirtualMachine currVm = (VirtualMachine)mes[i];\r\n\t\t\tSystem.out.printf(\"vm[%d]: Name = %s\\n\", i, currVm.getName());\r\n\t\t}\r\n\t}", "@Override\n\tpublic void run() {\n\t\tSystem.out.println(\"hi deepali\");\n\t\t\n\t}", "public void geraeuschMachen() {\n System.out.println(\"BRUELL\");\n }", "@Override\n\tpublic void voler() {\n\t\tSystem.out.println(\"JE SAIS PAS VOLER\");\n\t}", "public static void main(){\n\t}", "void displayResults(final InvokeResult[] results)\n {\n for (int i = 0; i < results.length; ++i)\n {\n final InvokeResult result = results[i];\n\n final String s = new SmartStringifier(\"\\n\", false).stringify(result);\n println(s + \"\\n\");\n }\n }", "public void summary (java.io.PrintStream out) { throw new RuntimeException(); }", "public void toJMVA() {\r\n \t\tmc = new ModelChecker(model, model, model, model, true);\r\n \t\tpw = new JModelProblemsWindow(mainWindow, mc, this);\r\n \t\tif (!mc.isEverythingOkToJMVA()) {\r\n \t\t\tpw.show();\r\n \t\t}\r\n \t\tif (mc.isEverythingOkToJMVA() || ((!mc.isEverythingOkToJMVA()) && (pw.continued()))) {\r\n \t\t\tif (checkForSave(\"<html>Save changes before switching?</html>\")) {\r\n \t\t\t\treturn;\r\n \t\t\t}\r\n \t\t\t// try {\r\n \t\t\t// New Converter by Bertoli Marco\r\n \t\t\tExactModel output = new ExactModel();\r\n \t\t\tList res = ModelConverter.convertJSIMtoJMVA(model, output);\r\n \t\t\tExactWizard jmva = new ExactWizard(output);\r\n \t\t\t// If problems are found, shows warnings\r\n \t\t\tif (res.size() > 0) {\r\n \t\t\t\tnew WarningWindow(res, jmva, CommonConstants.JSIM, CommonConstants.JMVA).show();\r\n \t\t\t}\r\n \r\n \t\t\t/*\r\n \t\t\t * Old code to use XSLT transformer (really bugged and unfinished)\r\n \t\t\t * \r\n \t\t\t * File xmlTempFile = File.createTempFile(\"~SIMtoMVA\", \".xml\");\r\n \t\t\t * xmlTempFile.deleteOnExit(); File destFile =\r\n \t\t\t * File.createTempFile(\"~MVA\", \".xml\"); destFile.deleteOnExit();\r\n \t\t\t * InputStream stream =\r\n \t\t\t * XSDSchemaLoader.loadSchemaAsStream(XSDSchemaLoader.JSIM_TO_JMVA);\r\n \t\t\t * if(stream==null){ System.out.println(\"stream is null\"); return; }\r\n \t\t\t * XMLWriter.writeXML(xmlTempFile, model); InputStream is = new\r\n \t\t\t * BufferedInputStream(stream); Transformer transformer =\r\n \t\t\t * TransformerFactory.newInstance().newTransformer(new\r\n \t\t\t * StreamSource(is)); StreamSource ssrc = new\r\n \t\t\t * StreamSource(xmlTempFile); StreamResult srst = new\r\n \t\t\t * StreamResult(destFile); transformer.transform(ssrc, srst);\r\n \t\t\t * xmlTempFile.delete(); ExactModel xm = new ExactModel();\r\n \t\t\t * xm.loadDocument(new XMLUtils().loadXML(destFile)); new\r\n \t\t\t * ExactWizard(xm); }catch (Exception e) { handleException(e); }\r\n \t\t\t */\r\n \t\t}\r\n \t}", "public void saveResult(PrintWriter P) {\n \n System.out.println(\"CaseListMem: Not implemented\");\n}", "public static void main( String args[] )\n {\n double Ei = 500;\n double EPS = 10;\n double phi = 60;\n float mutS = 0.1f;\n float mutA = 0.2f;\n float gamma = 45;\n double energy = Ei - EPS;\n\n double self = SelfShielding( energy, Ei, phi, mutS, mutA, gamma );\n System.out.println( \"self shielding factor = \" + self );\n // result should be: 1.1944503488285683\n\n String filename = \"/usr2/HRCS_TEST/hrcs3084.run\";\n RunfileRetriever rr = new RunfileRetriever( filename );\n DataSet ds = rr.getDataSet(1);\n Operator ToEL = new SpectrometerTofToEnergyLoss( ds, 0, 0, 0 );\n ds = (DataSet)ToEL.getResult();\n new ViewManager( ds, IViewManager.IMAGE );\n\n Vector result = SelfShielding( ds, mutS, mutA, gamma, true );\n\n DataSet ss_ds_1 = (DataSet)result.elementAt(0); \n new ViewManager( ss_ds_1, IViewManager.IMAGE );\n\n DataSet ss_ds_2 = (DataSet)result.elementAt(1); \n new ViewManager( ss_ds_2, IViewManager.IMAGE );\n }", "public void Run(boolean has_probe){\n hasProbe = has_probe;\n if (hasProbe){\n primerNum = 6;\n } else {\n primerNum = 4;\n }\n\n setUpBases();\n setUpCts();\n\n EnvMaker envMaker = new EnvMaker(pFilename, hasProbe);\n\n primers = envMaker.setPrimers();\n pNames = envMaker.getpNames();\n pLens = envMaker.getpLens();\n\n //Combined primer length - needed for combined mismatch freq\n mLen = primers[0].length() + primers[primerNum /2 -1].length();\n\n envMaker.checkSeqs(sFilename);\n\n buildSeqList(envMaker, envMaker.getSeqCount());\n //End Setup\n\n try {\n outFilename = sFilename + \"_out.txt\";\n\n FileWriter fstreamOut = new FileWriter(outFilename);\n BufferedWriter outOut = new BufferedWriter(fstreamOut);\n\n outFilename = sFilename + \"_cts.txt\";\n\n FileWriter fstreamCT = new FileWriter(outFilename);\n BufferedWriter outCT = new BufferedWriter(fstreamCT);\n\n //outputPrinter printer = new outputPrinter(sFilename, pLens);\n\n //Loop through each sequence in turn\n for (int s = 0; s < compSeqs.length; s++) {\n success = false;\n\n try {\n\n //outFilename=sFilename.substring(0, sFilename.lastIndexOf(\".\"))+\"_\"+s+\"_matrix.txt\";\n outFilename=sFilename+\"_\"+(s+1)+\"_matrix.txt\";\n\n tTx=\"Evaluating seq \"+(s+1)+\" \"+seqNames[s];\n System.out.println(tTx);\n outOut.write(tTx+System.getProperty(\"line.separator\"));\n\n //Clear results - 6 for F/P/R*2, 14 for all the different mutation counts - plus one for Ns now\n scores = new int[compSeqs[s].length()][primerNum][16];\n\n runMismatchDetection(s);\n\n PrintCandidatePos(outOut);\n }//matrix outputFile try\n\n catch (Exception e) {\n e.printStackTrace();\n System.err.println(\"Error: \" + e.getMessage());\n }\n\n if(!success) {\n noHits+=seqNames[s]+\"\\tNOHIT\"+System.getProperty(\"line.separator\");\n }\n }//end of comSeq loop s - evaluate each seq\n\n outOut.close();\n\n outCT.write(noHits);\n outCT.close();\n }//cts outFile try\n catch (Exception e) {\n e.printStackTrace();\n System.err.println(\"Error: \" + e.getMessage());\n }\n System.out.println(\"GoPrime finished...Exiting\");\n }", "public static void processNormal(String[] va, VirtualMemory vm){\n int result;\n for(int i=0; i<va.length; i+=2){\n if(Integer.parseInt(va[i])==0){\n result = vm.read(Integer.parseInt(va[i+1]));\n if(result==-1)\n System.out.print(\"pf\");\n else if(result==0)\n System.out.print(\"err\");\n else\n System.out.print(result);\n }\n else{\n result = vm.write(Integer.parseInt(va[i+1]));\n if(result==-1)\n System.out.print(\"pf\");\n else\n System.out.print(result);\n }\n if(i!=va.length-2)\n System.out.print(\" \");\n }\n }", "public void process() {\n\t\tSystem.out.println(\"snapdragonm 888\");\n\n\t}", "public void powerOff() \n {\n try \n {\n // your code here\n \tSystem.out.println(\"Powering off virtual machine '\"+vm.getName() +\"'. Please wait...\"); \n \tTask t=vm.powerOffVM_Task();\n \tif(t.waitForTask()== Task.SUCCESS)\n \t{\n\t \tSystem.out.println(\"Virtual machine powered off.\");\n\t \tSystem.out.println(\"====================================\");\n \t}\n \telse\n \t\tSystem.out.println(\"Power off failed / VM already powered on...\");\n \t\n } catch ( Exception e ) \n { \n \tSystem.out.println( e.toString() ) ; \n }\n }", "public static void main(String[] args) throws Exception {\n\t\tStoreAlphaWeight.dimensionForSVM=200;\n\t\tLibEstimate le=new LibEstimate();\n\t\tle.countLine();\n\t\tle.readVec();\n\t\tle.readLabel();\n\t\tle.readBias();\n\t\tle.addBiastoVec();\n\t\tle.prepTrainData();\n\t\tle.prepTestData();\n\t\tle.lib();\n\t}", "public void Main(){\n }", "@Override\n\tpublic void activity() {\n\t\tSystem.out.println(\"relaxing\");\n\t}", "static void perform_mvi(String passed){\n\t\tint type = type_of_mvi(passed);\n\t\tif(type==1)\n\t\t\tmvi_to_reg(passed);\n\t\telse if(type==2)\n\t\t\tmvi_to_mem(passed);\n\t}", "public ArrayList execute() {//(MultivariateFunction func, double[] xvec, double tolfx, double tolx) \n num_Function_Evaluation = 0;\n double[] stat = {0.0, 0.0};\n double[] storeBest = null;\n double[] storeMean = null;\n double[] storeStd = null;\n if (isOptimization) {\n storeBest = new double[101];\n storeMean = new double[101];\n storeStd = new double[101];\n //System.out.println(\"Initialization Done\");\n }\n int storeIndex = 0;\n\n //f = func;\n //bestSolution = xvec;\n // Create first generation\n firstGeneration();\n //System.out.println(iRet+\" \"+returnResult[iRet]);\n //stopCondition(fx, bestSolution, tolfx, tolx, true);\n\n //main iteration loop\n while (true) {\n boolean xHasChanged;\n do {\n //printing steps\n if (isPrintSteps) {\n if (currGen % printStep == 0) {\n if (isOptimization) {\n if (storeIndex < 101) {\n storeBest[storeIndex] = fx;\n stat = computFitnessStat();\n storeMean[storeIndex] = stat[0];\n storeStd[storeIndex] = stat[1];\n storeIndex++;\n }\n }\n System.out.printf(\" MH algo It: %5d Best: %.9f Mean: %.9f Std: %.9f \\n\", currGen, fx, stat[0], stat[1]);\n }//printsteps\n }//isPrintSteps\n\n xHasChanged = nextGeneration();\n if (currGen >= maxIter) {//if (maxFun > 0 && numFun > maxFun)\n break;\n }\n //if (prin > 1 && currGen % 20 == 0)\n //printStatistics();\n } while (!xHasChanged);\n //if (stopCondition(fx, bestSolution, tolfx, tolx, false) || (maxFun > 0 && numFun > maxFun))\n if (currGen >= maxIter) {\n break;\n }\n if (fx < 0.0000001) {\n //System.out.println(\"treshold\" + fx);\n //break;\n }\n }//while\n //printing final step\n if (isPrintFinal) {\n if (isOptimization) {\n if (storeIndex < 101) {\n storeBest[storeIndex] = fx;\n stat = computFitnessStat();\n storeMean[storeIndex] = stat[0];\n storeStd[storeIndex] = stat[1];\n storeIndex++;\n }\n }\n System.out.printf(\" MH algo It: %5d Best: %.9f Mean: %.9f Std: %.9f \\nTotal Fun Evaluations: %d\\n\", currGen, fx, stat[0], stat[1], num_Function_Evaluation);\n }\n ArrayList array = new ArrayList();\n array.add(storeBest);\n array.add(storeMean);\n array.add(storeStd);\n return array;\n }", "static void displayMessage() {\n\n System.out.println(\"\\nA total of \" + graphVisited.size() + \" vertices visited\");\n\n System.out.println(\"Found \" + silhouetteAnalyzer(numberOfVertices)\n + \" silhouettes\");\n }", "private static void simpleRun(String [] args){\n\t\tString applicationPath = convertApplication(args[2], null);\n\t\tboolean testHardware = args[0].equals(\"-testCGRAVerilog\");\n\t\t\n\t\t\n\t\tboolean synthesis = false;\n\t\tif(args[0].equals(\"-testCGRAVerilog\") || args[3].equals(\"true\")){\n\t\t\tsynthesis = true;\n\t\t} else if (args[3].equals(\"false\")){\n\t\t\tsynthesis = false;\n\t\t} else{\n\t\t\tSystem.out.println(\"Synthesis parameter not set correctly: \" + args[3]+ \"\");\n\t\t\tSystem.out.println(\"Valid values are \\\"true\\\" and \\\"false\\\"\");\n\t\t\tSystem.out.println(\"Aborting...\");\n\t\t\treturn;\n\t\t}\n\t\t\n\t\t\n\t\tConfMan configManager = new ConfMan(args[1], applicationPath, synthesis);\n\t\t\n\t\tTrace simpleRunTrace = new Trace(System.out, System.in, \"\", \"\");\n\t\tif(configManager.getTraceActivation(\"config\")){\n\t\t\tsimpleRunTrace.setPrefix(\"config\");\n\t\t\tconfigManager.printConfig(simpleRunTrace);\n\t\t}\n\n\t\tDecimalFormatSymbols symbols = new DecimalFormatSymbols();\n\t\tsymbols.setGroupingSeparator(',');\n\t\tsymbols.setDecimalSeparator('.');\n\t\tDecimalFormat formater = new DecimalFormat(\"#.000\", symbols);\n\t\t\n\t\tAmidarSimulationResult results = run(configManager, null, testHardware);\n\t\t\n\t\tif(configManager.getTraceActivation(\"results\")){\n\t\t\tsimpleRunTrace.setPrefix(\"results\");\n\t\t\tsimpleRunTrace.printTableHeader(\"Simulated \"+applicationPath+\" - Synthesis \"+(configManager.getSynthesis()?\"ON\":\"OFF\"));\n\t\t\tsimpleRunTrace.println(\"Ticks: \"+results.getTicks());\n\t\t\tsimpleRunTrace.println(\"Bytecodes: \"+results.getByteCodes());\n\t\t\tsimpleRunTrace.println(\"Energy consumption: \"+formater.format(results.getEnergy()));\n\t\t\tsimpleRunTrace.println(\"Execution Time: \"+results.getExecutionDuration()+\" ms\");\n\t\t\tsimpleRunTrace.printTableHeader(\"Loop Profiling\");\n\t\t\tresults.getProfiler().reportProfile(simpleRunTrace);\n\t\t\tsimpleRunTrace.printTableHeader(\"Kernel Profiling\");\n\t\t\tresults.getKernelProfiler().reportProfile(simpleRunTrace, results.getTicks());\n\t\t}\n\t\t\n\t\tif(testHardware){\n\t\t\tsimpleRunTrace.setPrefix(\"CGRA verilog test\");\n\t\t\tsimpleRunTrace.printTableHeader(\"Testing CGRA Verilog descrption\");\n\t\t\tAmidar core = results.getAmidarCore();\n\t\t\tCGRA myCGRA = (CGRA)core.functionalUnits[core.functionalUnits.length-1]; // CGRA is the last one\n\t\t\t\n\t\t VerilogGenerator gen = target.Processor.Instance.getGenerator();\n\t\t CgraModel model = myCGRA.getModel();\n\t\t model.finalizeCgra();\n\t\t simpleRunTrace.println(\"Generate Verilog...\");\n\t\t gen.printVerilogDescription(\"out\",model);\n\t\t TestbenchGeneratorAmidar tbgen = new TestbenchGeneratorAmidar((VerilogGeneratorAmidar) gen);\n\t\t StimulusAmidar[] stimuli = new StimulusAmidar[1];\n\t\t stimuli = myCGRA.getStimulus().toArray(stimuli);\n\t\t TestbenchContextGenerator tbcongen = new TestbenchContextGenerator(model);\n\t\t tbcongen.exportContext(myCGRA.getContextCopyPEs(), myCGRA.getContextCopyCBOX(), myCGRA.getContextCopyCCU());\n//\t\t for(Stimulus stim : stimuli){\n//\t\t \tSystem.out.println(stim);\n//\t\t }\n\t\t \n\t\t tbgen.exportAppAndPrintTestbench(stimuli);\n\t\t \n//\t\t tbgen.importAppAndPrintTestbench(\"SimpleTest.main\");\n\t\t TestbenchExecutor tbex = new TestbenchExecutor();\n\t\t \n\t\t if(tbex.runTestbench()){\n\t\t \tsimpleRunTrace.println(\"Run was successful - Cosimulation succeeded\");\n\t\t }\n\t\t else{\n\t\t \tConsistencyChecker sammi = new ConsistencyChecker();\n\t\t \tboolean mismatch = sammi.findRegfileMismatch();\n\t\t \tif(mismatch){\n\t\t \t\tsimpleRunTrace.println(\"Error(s) during Simulation. Something went wrong in the data path\");\n\t\t \t}\n\t\t \telse{\n\t\t \t\tsimpleRunTrace.println(\"Emulation / HDL missmatch. Maybe there's is something not equal concerning the communication or FSM.\");\n\t\t \t}\n\t\t }\n\t\t}\n\t\t\n\n\t}", "@Override\r\n\t\t\t\tpublic void run() {\n\t\t\t\t\tlblstatus.setText(\"Hardware Problem\");\r\n\t\t\t\t\tToast.makeText(Main.mainstage, \"Hardware Problem\", 1000,\r\n\t\t\t\t\t\t\t100, 100);\r\n\r\n\t\t\t\t}", "@Test\n\tpublic void whenExecuteMainThenPrintToConsole() {\n\t\tByteArrayOutputStream out = new ByteArrayOutputStream();\n\t\tSystem.setOut(new PrintStream(out));\n\t\tCalculate.main(null);\n\t\tassertThat(out.toString(), is(\"Hello World\\r\\n\"));\n\t}", "ProbeResult run();", "public static void main(String[] args) {\n\t\tVendingMachine vm = new VendingMachine();\r\n\t\tVendingMachine vm1 = new VendingMachine(100);\r\n\t\tVendingMachine vm2 = new VendingMachine(100.1);\r\n\t\tvm.showPrompt();\r\n\t\tvm.showBalance();\r\n\t\tvm.insertMoney(100);\r\n\t\tvm.getFood();\r\n\t\tvm.showBalance();\r\n\t\tvm1.insertMoney(50);\r\n\t\tvm1.showBalance();\r\n\r\n\t}", "public void engineFailureStatus() {\n \tthis.engineFailureActive = this.trainModelGUI.engineFailStatus();\n }", "public static void main(String[] args) {\n\t\tresult obj = new result();\n\t\tobj.setstudent(\"penny\", 30);\n\t\tobj.setmarks(95, 85);\n\t\tobj.calculate();\n\t\tobj.showstudent();\n\t\tobj.showmarks();\n\t\tobj.showresult();\n\n\t}", "public void testCycleHaltAddM() \r\n\t{\n\t\tMemory testProgram1 = new Memory(3);\r\n\t\ttestProgram1.store(0, \"00000000\");\r\n\t\ttestProgram1.store(1, \"00100111\");\r\n\t\ttestProgram1.store(2, \"11100111\");\r\n\t\t\r\n\t\tCPU testCPU = new CPU(testProgram1);\r\n\t\t\r\n\t\t//check haltCalledbefore the action is executed\r\n\t\tassertEquals(false, testCPU.getHaltCalled());\t\t\r\n\t\ttestCPU.cycle();\r\n\t\t//check haltCalled after the action is performed\r\n\t\tassertEquals(true, testCPU.getHaltCalled());\t\r\n\t\t\r\n\t\t//Check the accumulator before the rest is program is executed\r\n\t\tassertEquals(\"00000000\", testCPU.getAccumulator());\r\n\t\tassertEquals(0, testCPU.getAccumulatorDecimal());\r\n\t\ttestCPU.executeProgramInMemory();\r\n\t\t//Check the accumulator after the program has been executed\r\n\t\tassertEquals(\"00000000\", testCPU.getAccumulator());\r\n\t\tassertEquals(0, testCPU.getAccumulatorDecimal());\r\n\t\t\r\n\t\t//This program modifies the aaccumulator and then call halt\r\n\t\tMemory testProgram2 = new Memory(3);\r\n\t\ttestProgram2.store(0, \"10100111\");\r\n\t\ttestProgram2.store(1, \"00000000\");\r\n\t\ttestProgram2.store(2, \"11100111\");\r\n\t\t\r\n\t\ttestCPU.setMemory(testProgram2);\r\n\t\t\r\n\t\t//Check the accumulator before execution\r\n\t\tassertEquals(\"00000000\", testCPU.getAccumulator());\r\n\t\tassertEquals(0, testCPU.getAccumulatorDecimal());\r\n\t\t//check accumulator after the rest of the program has been executed\r\n\t\ttestCPU.executeProgramInMemory();\r\n\t\tassertEquals(\"00000111\", testCPU.getAccumulator());\r\n\t\tassertEquals(7, testCPU.getAccumulatorDecimal());\r\n\t\t\r\n\t\t\r\n\t\t//This program call halt at the beginning then call it again\r\n\t\t//it check that even the halt it call again nothing is execute\r\n\t\t//after the first call\r\n\t\tMemory testProgram3 = new Memory(4);\r\n\t\ttestProgram3.store(0, \"00000000\");\r\n\t\ttestProgram3.store(1, \"10100111\");\r\n\t\ttestProgram3.store(2, \"00000000\");\r\n\t\ttestProgram3.store(3, \"10100111\");\r\n\t\t\r\n\t\ttestCPU.setMemory(testProgram3);\r\n\t\r\n\t\t//Check the accumulator before execution\r\n\t\tassertEquals(\"00000000\", testCPU.getAccumulator());\r\n\t\tassertEquals(0, testCPU.getAccumulatorDecimal());\r\n\t\ttestCPU.executeProgramInMemory();\r\n\t\t//check accumulator after the rest of the program has been executed\r\n\t\tassertEquals(\"00000000\", testCPU.getAccumulator());\r\n\t\tassertEquals(0, testCPU.getAccumulatorDecimal());\r\n\t}", "public void train ()\t{\t}", "public static void main(String[] args) {\n \tString writer=\"\";\n \tString vehicleReader=\"\";\n \tString platoonReader=\"\";\n \tString roadReader=\"\";\n String writerLog =\"\";\n\n VanetFSM fsm = new VanetFSM(writer, writerLog,null,null,null,null); \n ArrayList<VanetProperty> props = new ArrayList<VanetProperty>();\n props.add(new Property1());\n props.add(new Property2());\n props.add(new Property3());\n props.add(new Property4());\n props.add(new Property5());\n executeAndMonitor(fsm, props);\n }", "public void run() {\n\t\t\tshowSystemDialog(ResultMsg);\r\n\t\t}", "public static void main(String args[]) {\n\n\ttry {\n\n\t CommandTokenizer parser = new CommandTokenizer(\"--\");\n\t parser.parse(args);\n\t ConfigurationProperties config = parser.getMap();\n\n\t Logger slogger = LogManager.getLogger(\"SIM\");\n\t slogger.setLogLevel(config.getIntValue(\"log-level\", 3));\n\t ConsoleLogHandler console = new ConsoleLogHandler(new SimulationLogFormatter());\n\t console.setLogLevel(config.getIntValue(\"log-level\", 3));\n\t slogger.addHandler(console);\n\n\t LogProxy logger = new LogProxy(\"QST\",\"\",slogger);\n\n\t Site site = new Site(config.getProperty(\"site\"), \n\t\t\t\t Math.toRadians(config.getDoubleValue(\"lat\")), \n\t\t\t\t Math.toRadians(config.getDoubleValue(\"long\")));\n\t \n\t long start = (ScheduleSimulator.sdf.parse(config.getProperty(\"start\"))).getTime();\n long end = (ScheduleSimulator.sdf.parse(config.getProperty(\"end\"))).getTime();\n\n\t // Instruments.\n\t InstrumentRegistry instruments = (InstrumentRegistry)Naming.lookup(\"rmi://localhost/InstrumentRegistry\");\n\t \n\t // Exec model\n\t File bxf = new File(config.getProperty(\"exec\")); // exec model properties\n BasicExecutionTimingModel bxtm = new BasicExecutionTimingModel(site, instruments);\n\t PropertiesConfigurator.use(bxf).configure(bxtm);\n\n\t // Allow 2 day for this test...\n bxtm.setExternalTimeConstraint(end+30*24*3600*1000L, \"End of simulation\");\n\n\t // Stochastic wrapper.\n\t //File bsef = new File(config.getProperty(\"sexm\")); // stochastic exec model properties\n\t //BasicStochasticExecutionTimingModel bsem = new BasicStochasticExecutionTimingModel(bxtm);\n\t //PropertiesConfigurator.use(bsef).configure(bsem);\n\n\t // TC window calculator.\n\t BasicTimingConstraintWindowCalculator btcwc = new BasicTimingConstraintWindowCalculator(bxtm, site, 5*60*1000L);\n\n\t // Charging\n\t File bcaf = new File(config.getProperty(\"cost\")); // charge model properties\n\t BasicChargeAccountingModel bcam = new BasicChargeAccountingModel();\n\t PropertiesConfigurator.use(bcaf).configure(bcam);\n\n\t // Selector\n //BasicSelectionHeuristic bsel = new BasicSelectionHeuristic();\n\n\t // Env prediction\n\t File bepf = new File(config.getProperty(\"env\")); // Environment properties\t \n\t BasicEnvironmentPredictor bep = new BasicEnvironmentPredictor();\n\t PropertiesConfigurator.use(bepf).configure(bep); \n\t //BasicMutableEnvironmentPredictor bep = new BasicMutableEnvironmentPredictor();\n\t //bep.setPhotom(true);\n\t //bep.setSeeing(seeing);\n\n\n\t // Weather prediction - this will be replaced with Weather scenario model\n\t //File swpf = new File(config.getProperty(\"weather\")); // weather properties\n\t //StandardWeatherPredictor swp = new StandardWeatherPredictor();\n\t //PropertiesConfigurator.use(swpf).configure(swp);\n\t // and pre-compute weather for the full run\n\t //swp.preCompute(start, end);\n\t BasicMutableWeatherModel bwm = new BasicMutableWeatherModel();\n\t bwm.setGood(true);\n\n\t // RTC\n\t // RemainingTimeCalculator rtc = new DummyRemainingTimeCalculator();\n\n\t // ODB\n\t String root = config.getProperty(\"root\");\n\t \n\t Phase2ModelProvider provider = (Phase2ModelProvider)Naming.\n\t\tlookup(\"rmi://localhost/\"+root+\"_Phase2ModelProvider\");\n\t Phase2Model phase2 = provider.getPhase2Model();\n\n\t // History\n BasicHistoryModel history = new BasicHistoryModel();\n\t history.loadHistory(phase2, start);\n\n\t BasicAccountingModel bam = new BasicAccountingModel();\n\t bam.loadAccounts(phase2, start);\n\n\n\t // Select a scoring model here - there will be others \n\t // Scoring model\n\t File smf = new File(config.getProperty(\"score\")); // bogstandard scoring properties\n\t BasicScoringModel bsm = new BasicScoringModel(site);\n\t PropertiesConfigurator.use(smf).configure(bsm);\n\t \n\t BasicCandidateGenerator bcg = new BasicCandidateGenerator(phase2,\n\t\t\t\t\t\t\t\t history,\n\t\t\t\t\t\t\t\t bam,\n\t\t\t\t\t\t\t\t bxtm,\n\t\t\t\t\t\t\t\t bsm);\n\n\n\t // Alternative using despath scheduler\n\t BasicSelectionHeuristic selector = new BasicSelectionHeuristic();\n \t BasicDespatcher bds = new BasicDespatcher(bcg,\n\t\t\t\t\t\t selector);\n\n\n\t slogger.log(1, \"Start sim run...\");\n\n\t // fixed env for now\n\t EnvironmentSnapshot env = new EnvironmentSnapshot();\n\t env.seeing = Group.EXCELLENT;\n\t env.photom = true;\n\n\t // setup some stats.\n\t PriorityUtilityCalculator puc;\n\t OptimalAirmassUtilityCalculator oauc;\n\t RemainingNightsUtilityCalculator rnuc;\n\t ScoringUtilityCalculator suc;\n\n\t oauc = new OptimalAirmassUtilityCalculator(site, btcwc, bxtm, 5*60*1000L);\n\t puc = new PriorityUtilityCalculator(bxtm);\n\t rnuc = new RemainingNightsUtilityCalculator(btcwc);\n\t suc = new ScoringUtilityCalculator(bxtm, bsm, bam);\n \n\t double pqm =0.0;\n\t double oaqm = 0.0;\n\t double rnqm = 0.0;\n\t double xtqm = 0.0;\n\t double ngqm = 0.0;\n\t double sqm = 0.0;\n\n\t int it = 0;\n\t //while (t < end) {\n\n\t int ndays = (int)((end - start)/86400000);\n\t\n\t // run for many days\t\t\n\t for (int in = 0; in < ndays; in++) {\n\t\t\n\t\tlong ds = start + in*86400*1000L;\n\t\tlong de = ds + 86400*1000L;\n\t\t\n\t\t// work out the night length\n\t\tlong night = 0L;\n\t\tlong astro = 0L;\n\t\tlong t = ds;\n\t\twhile (t < de) {\n\t\t Position sun = Astrometry.getSolarPosition(t);\n\t\t double sunElev = sun.getAltitude(t, site);\n\t\t if (sunElev < 0.0)\n\t\t\tnight += 5*60*1000L;\n\t\t if (sunElev < Math.toRadians(-18.0))\n\t\t\tastro += 5*60*1000L;\n\t\t t += 5*60*1000L;\n\t\t}\n\t\t\n\t\t// DAILY totals\n\t\tint ngs = 0;\n\t\tdouble phm = 0.0;\n\t\tdouble oahm = 0.0;\n\t\tdouble rnhm = 0.0;\n\t\tdouble xtm = 0.0;\n\t\tdouble shm = 0.0;\n\n\t\t// a days worth\n\t\tt = ds;\n\t\twhile (t < de) {\n\t\t \n\t\t Position sun = Astrometry.getSolarPosition(t);\n\t\t if (sun.getAltitude(t, site) > Math.toRadians(-1.0)) {\n\t\t\tt += 5*60*1000L;\n\t\t\tlogger.log(1, \"SUNUP at \"+ScheduleSimulator.sdf.format(new Date(t)));\n\t\t\tcontinue;\n\t\t }\n\t\t \n\t\t // Using BDS\n\t\t Metric metric = bds.getScheduleItem(t, env);\n\t\t \n\t\t if (metric == null) {\n\t\t\tt += 5*60*1000L;\n\t\t\tlogger.log(1, \"SELECT \"+it+\" at \"+ScheduleSimulator.sdf.format(new Date(t))+\" NONE\");\n\t\t } else {\n\t\t\t\n\t\t\tGroup group = metric.group;\n\t\t\tExecutionStatistics hist = history.getExecutionStatistics(group);\n\t\t\tlong xt = bxtm.getExecTime(group);\n\t\t\t\n\t\t\t// SQM updates\n\t\t\tngs++;\n\t\t\tphm += puc.getUtility(group, t, env, hist);\n\t\t\toahm += oauc.getUtility(group, t, env, hist);\n\t\t\trnhm += rnuc.getUtility(group, t, env, hist);\t\t\n\t\t\txtm += (double)xt;\n\t\t\tshm += suc.getUtility(group, t, env, hist);\n\n\t\t\tlogger.log(1, \"SELECT \"+it+\" at \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+group.getName()+\n\t\t\t\t \" until \"+ScheduleSimulator.sdf.format(new Date(t+xt)));\n\t\t\tt += xt;\n\t\t\thistory.updateHistory(group, t-10000L);\n\t\t\t\n\t\t }\n\t\t it++;\n\t\t}\n\n\t\t// daily averages\n\t\tlogger.log(1, \"CDAT_NG \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+ngs);\n\t\tlogger.log(1, \"CDAT_PX \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+(phm/night));\n\t\tlogger.log(1, \"CDAT_OA \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+(oahm/(double)ngs));\n\t\tlogger.log(1, \"CDAT_RN \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+(rnhm/(double)ngs));\n\t\tlogger.log(1, \"CDAT_XT \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+((double)xtm/night));// hours\n\t\tlogger.log(1, \"CDAT_SU \"+ScheduleSimulator.sdf.format(new Date(t))+\" \"+shm);\n\t\t\n\t\tngqm += ngs;\n\t\tpqm += phm/night;\n\t\toaqm += oahm/(double)ngs;\n\t\trnqm += rnhm/(double)ngs;\n\t\txtqm += xtm/3600000.0;\n\t\tsqm += shm;\n\n\t } // next day\n\t \n\t // averages for SQM\n\t logger.log(1, \"CDAT_SQ_NG \"+(ngqm/(double)ndays));\n\t logger.log(1, \"CDAT_SQ_PX \"+(pqm/(double)ndays));\n\t logger.log(1, \"CDAT_SQ_OA \"+(oaqm/(double)ndays));\n\t logger.log(1, \"CDAT_SQ_RN \"+(rnqm/(double)ndays));\n\t logger.log(1, \"CDAT_SQ_XT \"+(xtqm/(double)ndays));// hours\n\t logger.log(1, \"CDAT_SQ_SU \"+(sqm/(double)ndays));\n\t \n\t} catch (Exception e) {\n\t e.printStackTrace();\n\t return;\n\t}\n\t\n }", "@Override\n\tpublic void getManResult(Man man) {\n\t\tSystem.out.println(\"ÄÐÈËʧ°Ü\");\n\t}", "protected void execute() {\n\t\t\r\n\t\tParticleAnalysisReport[] reports = simpleVision.getFrame();\r\n\t\t for (int i = 0; i < reports.length; i++) { // print results\r\n ParticleAnalysisReport r = reports[i];\r\n SmartDashboard.putString(\"Particle\" + i, r.center_mass_x + \", \" + r.center_mass_y);\r\n\t\t }\r\n\t\t\r\n\t}", "protected void end() {\r\n lang.nextStep();\r\n int total = seen + failed;\r\n\r\n hideAll();\r\n SourceCode end = lang.newSourceCode(new Offset(0, 50, pMap.get(\"hRect\"),\r\n \"SW\"), \"end\", null, sourceCodeProperties);\r\n end.addCodeLine(\r\n \"Das h\\u00F6chste Ergebnis, dass der Spieler bei einem optimal spielenden Gegner erzielen kann, ist \"\r\n + result + \".\", \"end\", 0, null);\r\n if (seen == 1) {\r\n end.addCodeLine(\"Von den insgesamt \" + nodesTotal + \" Knoten wurde \"\r\n + seen + \" nur Knoten untersucht.\", \"end\", 0, null);\r\n } else {\r\n end.addCodeLine(\"Von den insgesamt \" + nodesTotal + \" Knoten wurden \"\r\n + seen + \" verschiedene Knoten untersucht.\", \"end\", 0, null);\r\n }\r\n if (pruned == 1) {\r\n end.addCodeLine(\"Es wurde \" + pruned + \" Knoten gepruned.\", \"end\", 0,\r\n null);\r\n } else {\r\n end.addCodeLine(\"Es wurde \" + pruned + \" Knoten gepruned.\", \"end\", 0,\r\n null);\r\n }\r\n if (failed == 1) {\r\n end.addCodeLine(\"Allerdings musste auch \" + failed\r\n + \" Knoten erneut untersucht werden, weil es zum Fail High kam.\",\r\n \"end\", 0, null);\r\n } else {\r\n end.addCodeLine(\"Allerdings mussten auch \" + failed\r\n + \" Knoten erneut untersucht werden, weil es zum Fail High kam.\",\r\n \"end\", 0, null);\r\n }\r\n end.addCodeLine(\"Damit wurde der Algorithmus insgesamt \" + total\r\n + \" Mal aufgerufen.\", \"end\", 0, null);\r\n end.addCodeLine(\r\n \"Im Vergleich dazu h\\u00E4tte der Minimax-Algorithmus alle \"\r\n + nodesTotal + \" Knoten einmal untersucht.\", \"end\", 0, null);\r\n end.addCodeLine(\"\", \"end\", 0, null);\r\n end.addCodeLine(\r\n \"Da der Algorithmus annimmt, dass jeweils der erste Kindknoten der beste ist \",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"und danach mit einem Nullwindow arbeitet, ist die Reihenfolge der Knoten sehr wichtig, \",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"damit m\\u00F6glichst viele Knoten gepruned werden und m\\u00F6glichst wenige erneut untersucht werden m\\u00FCssen.\",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"Es kann sich sogar zeitlich lohnen, die Knoten vorzusortieren.\",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"Bei unsortierten Knoten ist der Negascout-Algorithmus langsamer als das Alpha-Beta-Pruning,\",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"bei dem zwar weniger Knoten nicht untersucht werden, daf\\u00FCr aber auch keine erneut untersucht werden m\\u00FCssen.\",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"Die Komplexit\\u00E4t von Negascout betr\\u00E4gt O(b^d) in der Landau-Notation,\",\r\n \"end\", 0, null);\r\n end.addCodeLine(\r\n \"wobei b f\\u00FCr den Verzweigungsfaktor (branching factor) und d f\\u00FCr die Baumtiefe (depth) steht\",\r\n \"end\", 0, null);\r\n lang.nextStep(\"Conclusion\");\r\n }", "@Test\n public void testGetVer() {\n System.out.println(\"getVer\");\n VM instance = null;\n String expResult = \"\";\n String result = instance.getVer();\n assertEquals(expResult, result);\n // TODO review the generated test code and remove the default call to fail.\n fail(\"The test case is a prototype.\");\n }", "public static void printUsage(){\n \n System.out.println(\"USAGE:\\njava -jar LMB.jar inputfilename\\n\"\n + \"\\nWhere: LMB is the executable of this program\"\n + \"\\ninputfilename is a plaintext file located in the ./text/ folder\"\n + \"\\nAll output files will be created and written to the \\\"lm\\\" directory in root\");\n System.exit(1);\n \n }", "public static void test(String[] args) throws Exception {\n\t\tAbstractPILPDelegate.setDebugMode(null);\r\n\t\t\r\n\t\tComputeCostBasedOnFreq ins = new ComputeCostBasedOnFreq();\r\n\t\tins.initPreMapping(\"D:/data4code/replay/pre.csv\");\r\n\t\tins.getEventSeqForEachPatient(\"D:/data4code/cluster/LogBasedOnKmeansPlusPlus-14.csv\");\r\n\t\tins.removeOneLoop();\r\n\r\n\t\tPetrinetGraph net = null;\r\n\t\tMarking initialMarking = null;\r\n\t\tMarking[] finalMarkings = null; // only one marking is used so far\r\n\t\tXLog log = null;\r\n\t\tMap<Transition, Integer> costMOS = null; // movements on system\r\n\t\tMap<XEventClass, Integer> costMOT = null; // movements on trace\r\n\t\tTransEvClassMapping mapping = null;\r\n\r\n\t\tnet = constructNet(\"D:/data4code/mm.pnml\");\r\n\t\tinitialMarking = getInitialMarking(net);\r\n\t\tfinalMarkings = getFinalMarkings(net);\r\n\t\tXParserRegistry temp=XParserRegistry.instance();\r\n\t\ttemp.setCurrentDefault(new XesXmlParser());\r\n\t\tlog = temp.currentDefault().parse(new File(\"D:/data4code/mm.xes\")).get(0);\r\n//\t\tlog = XParserRegistry.instance().currentDefault().parse(new File(\"d:/temp/BPI2013all90.xes.gz\")).get(0);\r\n\t\t//\t\t\tlog = XParserRegistry.instance().currentDefault().parse(new File(\"d:/temp/BPI 730858110.xes.gz\")).get(0);\r\n\t\t//\t\t\tlog = XFactoryRegistry.instance().currentDefault().openLog();\r\n\t\tcostMOS = constructMOSCostFunction(net);\r\n\t\tXEventClass dummyEvClass = new XEventClass(\"DUMMY\", 99999);\r\n\t\tXEventClassifier eventClassifier = XLogInfoImpl.STANDARD_CLASSIFIER;\r\n\t\tcostMOT = constructMOTCostFunction(net, log, eventClassifier, dummyEvClass);\r\n\t\tmapping = constructMapping(net, log, dummyEvClass, eventClassifier);\r\n\r\n\t\tint cost1 = AlignmentTest.computeCost(costMOS, costMOT, initialMarking, finalMarkings, null, net, log,\r\n\t\t\t\tmapping, false);\r\n\t\tSystem.out.println(cost1);\r\n\t\t\r\n//\t\tint iteration = 0;\r\n//\t\twhile (true) {\r\n//\t\t\tSystem.out.println(\"start: \" + iteration);\r\n//\t\t\tlong start = System.currentTimeMillis();\r\n//\t\t\tint cost1 = AlignmentTest.computeCost(costMOS, costMOT, initialMarking, finalMarkings, null, net, log,\r\n//\t\t\t\t\tmapping, false);\r\n//\t\t\tlong mid = System.currentTimeMillis();\r\n//\t\t\tSystem.out.println(\" With ILP cost: \" + cost1 + \" t: \" + (mid - start));\r\n//\r\n//\t\t\tlong mid2 = System.currentTimeMillis();\r\n//\t\t\tint cost2 = AlignmentTest.computeCost(costMOS, costMOT, initialMarking, finalMarkings, null, net, log,\r\n//\t\t\t\t\tmapping, false);\r\n//\t\t\tlong end = System.currentTimeMillis();\r\n//\r\n//\t\t\tSystem.out.println(\" No ILP cost: \" + cost2 + \" t: \" + (end - mid2));\r\n//\t\t\tif (cost1 != cost2) {\r\n//\t\t\t\tSystem.err.println(\"ERROR\");\r\n//\t\t\t}\r\n//\t\t\t//System.gc();\r\n//\t\t\tSystem.out.flush();\r\n//\t\t\titeration++;\r\n//\t\t}\r\n\r\n\t}", "String diagnosticsOutput();", "public void show(Object errorMessage){\n\t\tSystem.out.println(\"Woops, something bad happened\");\n\t\tSystem.out.println(errorMessage);\n\t}", "void run() {\n\t\trunC();\n\t\trunPLMISL();\n\t\trunTolerance();\n\t\trunMatrix();\n\t}", "public void printInvalidVmMessage(String vmName){\r\n\t\tSystem.out.println(\"VM name is invalid : \"+vmName);\r\n\t}", "public static void main() {\n\t\tElectionDriverCode EDC = new ElectionDriverCode();\n\t\tSystem.setOut(EDC.fileout());\n\t}", "public static void main(String[] args){\n try {\r\n // m.nada(0);\r\n } catch (Exception ex) {\r\n System.out.println(\"No hay error\");\r\n }\r\n }", "public void getResults() {\n\t\tSystem.out.println(\"|V| : \" + g.getV());\n\t\tSystem.out.println(\"|E| : \" + g.getE());\n\t\tSystem.out.println(\"Max flow : \" + g.getVertex(sink).e);\n\t\tSystem.out.println(\"Run time : \" + (System.currentTimeMillis()-timeStart) + \" ms\"+\"\\n\");\n\t}", "void show() {\n System.out.print(\"show\");\n }", "public static void main (String[] argv)\n {\n\tdata = textToVectors ();\n\tprintDocumentVectors (data);\n\n\tLSAStats.setSizes (M, N);\n\n\t// 3. Make normalized data matrix. \n\t// Note: X is M x N\n\tdouble[][] X = LSAStats.normalizeData (data);\n\tLinUtil.print (\"X\", X);\n\n\t// Part (1): standard covariance \n\tdouble[][] covX = LSAStats.covariance (X);\n\tSystem.out.println (\"Covariance matrix without SVD\");\n\tLSAStats.printCovariance (covX);\n\n\t// Get coordinates using U as a basis.\n\tdouble[][] Y = latentSemanticCoords (X);\n\n\t// Part (2): Covariance in transformed coords.\n\tdouble[][] covY = LSAStats.covariance (Y);\n\tSystem.out.println (\"Covariance matrix in new coords:\");\n\tLSAStats.printCovariance (covY);\n }", "@Test(timeout = 4000)\n public void test03() throws Throwable {\n LovinsStemmer.main((String[]) null);\n }", "void printCheck();", "public void msgAllExecuted()\n {\n Alert allExecuted; // message when all block are computed\n allExecuted = new Alert(AlertType.INFORMATION);\n allExecuted.setTitle(\"Block editor\");\n allExecuted.setHeaderText(\"All block were successfully computed!\");\n allExecuted.setContentText(\"Clicking 'step' or 'run' button again will start new computation.\");\n allExecuted.showAndWait().ifPresent(rs -> {\n if (rs == ButtonType.OK) {}\n });\n }" ]
[ "0.71038115", "0.5967423", "0.5722872", "0.57188755", "0.55415463", "0.5526368", "0.55178076", "0.54995936", "0.5480185", "0.54713714", "0.5440552", "0.54299754", "0.54168236", "0.5399685", "0.53862476", "0.5355866", "0.5347202", "0.5345128", "0.53433114", "0.53328496", "0.53126764", "0.53100276", "0.530812", "0.52958137", "0.52826744", "0.5277513", "0.5275806", "0.52642715", "0.5258198", "0.5244979", "0.5228436", "0.522113", "0.5215955", "0.5205407", "0.5190654", "0.5187789", "0.5186192", "0.51818764", "0.51726544", "0.5171287", "0.51705354", "0.51638323", "0.51545703", "0.51480055", "0.51392657", "0.5135833", "0.5128739", "0.51249367", "0.5124866", "0.5123751", "0.5116496", "0.5113494", "0.511317", "0.510932", "0.5105108", "0.5095134", "0.50932074", "0.5090749", "0.50906426", "0.50899726", "0.5088098", "0.5085296", "0.50840545", "0.5075736", "0.50727725", "0.5065087", "0.50618947", "0.5061484", "0.505492", "0.5053929", "0.50486255", "0.5047221", "0.50471723", "0.50404036", "0.50297296", "0.5026851", "0.50224596", "0.50195354", "0.50187355", "0.5015448", "0.5012864", "0.5011945", "0.5011074", "0.5006934", "0.5005076", "0.5002075", "0.5001811", "0.50016725", "0.50014615", "0.5000901", "0.50007796", "0.5000777", "0.50002986", "0.499561", "0.49891847", "0.49874386", "0.49851316", "0.49834216", "0.49828604", "0.49824503" ]
0.6349821
1
obsolete. just for downward compatibility
public int train(final ArrayList<ME_Sample> vms, final int cutoff, final double sigma, final double widthfactor) { // convert ME_Sample to Sample // ArrayList<Sample> vs; _vs.clear(); for (ME_Sample i : vms) { add_training_sample(i); } return train(cutoff, sigma, widthfactor); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private stendhal() {\n\t}", "protected boolean func_70041_e_() { return false; }", "protected boolean func_70814_o() { return true; }", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "public final void mo51373a() {\n }", "@Override\n public void func_104112_b() {\n \n }", "public void method_4270() {}", "private void m50366E() {\n }", "@Deprecated\n\tprivate void oldCode()\n\t{\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n protected void prot() {\n }", "@Override\n\tprotected void interr() {\n\t}", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "@Override\n public void perish() {\n \n }", "public boolean method_218() {\r\n return false;\r\n }", "Compatibility compatibility();", "public final void mo91715d() {\n }", "public boolean method_4088() {\n return false;\n }", "public void m23075a() {\n }", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "public boolean method_194() {\r\n return false;\r\n }", "public boolean method_2453() {\r\n return false;\r\n }", "public boolean method_216() {\r\n return false;\r\n }", "private Rekenhulp()\n\t{\n\t}", "private NativeSupport() {\n\t}", "public abstract void mo70713b();", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "public abstract void mo56925d();", "private void kk12() {\n\n\t}", "@Override\r\n\tprotected void doF8() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "public boolean method_208() {\r\n return false;\r\n }", "void m1864a() {\r\n }", "@Override\n\tpublic void jugar() {\n\t\t\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "public boolean method_2434() {\r\n return false;\r\n }", "public void mo38117a() {\n }", "public boolean method_4093() {\n return false;\n }", "@Override\r\n\t\t\tpublic void func02() {\n\t\t\t\t\r\n\t\t\t}", "private ArraySetHelper() {\n\t\t// nothing\n\t}", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "public abstract void mo6549b();", "@Override\r\n\tprotected void func03() {\n\t\t\r\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "public boolean method_196() {\r\n return false;\r\n }", "@SuppressWarnings(\"unused\")\n\tprivate void version() {\n\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "public void m9741j() throws cf {\r\n }", "public boolean method_4132() {\n return false;\n }", "@Override\r\n\tprotected void doF4() {\n\t\t\r\n\t}", "@Override\n protected void init() {\n }", "public boolean method_214() {\r\n return false;\r\n }", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n public boolean getObsolete()\n {\n return false;\n }", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "public abstract void mo27386d();", "@Override\r\n\tprotected void doF6() {\n\t\t\r\n\t}", "private void strin() {\n\n\t}", "public void method_6349() {\r\n super.method_6349();\r\n }", "@Override\n protected void initialize() {\n\n \n }", "@Override\r\n\tprotected void initialize() {\n\r\n\t}", "public /* bridge */ /* synthetic */ void mo55097d() {\n super.mo55097d();\n }", "protected void mo6255a() {\n }", "public /* bridge */ /* synthetic */ void mo55096c() {\n super.mo55096c();\n }", "@Override\n\tpublic void anular() {\n\n\t}", "public final void mo8775b() {\n }", "@Override\n\tpublic void debite() {\n\t\t\n\t}", "public abstract void mo27385c();", "protected void method_2665() {\r\n super.method_2427(awt.field_4171);\r\n this.method_2440(true);\r\n this.method_2521(class_872.field_4244);\r\n }", "@Override\n protected void initialize() \n {\n \n }", "public void method_6191() {\r\n super.method_6191();\r\n }", "public boolean method_108() {\r\n return false;\r\n }", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "@Override\n\tprotected void initialize() {\n\n\t}", "public boolean method_210() {\r\n return false;\r\n }", "public void mo115190b() {\n }", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "@Override\n\tpublic void jugar() {}", "public void mo4359a() {\n }", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "public boolean method_4102() {\n return false;\n }", "@Override\n public void function()\n {\n }", "@Override\n public void function()\n {\n }", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "protected MetadataUGWD() {/* intentionally empty block */}", "public void mo21825b() {\n }", "@Override\n\tprotected void getExras() {\n\n\t}", "public void mo12628c() {\n }", "public /* bridge */ /* synthetic */ void mo55094a() {\n super.mo55094a();\n }", "@Override\n\tprotected void initialize() {\n\t}" ]
[ "0.6359502", "0.6302779", "0.6295758", "0.6142734", "0.61233854", "0.612282", "0.60925245", "0.60758257", "0.60369134", "0.60283774", "0.6024933", "0.5997845", "0.5971866", "0.59647965", "0.5914302", "0.5911314", "0.58930457", "0.5880401", "0.58774805", "0.58767027", "0.58643776", "0.58627874", "0.5840583", "0.58246076", "0.5818871", "0.5814606", "0.5813627", "0.5812637", "0.5812637", "0.57950854", "0.57830185", "0.57732755", "0.5763147", "0.5756739", "0.57488704", "0.5740196", "0.57370657", "0.57370657", "0.5736651", "0.57339615", "0.5728727", "0.57283586", "0.5726308", "0.57141566", "0.57141566", "0.57141566", "0.57141566", "0.57141566", "0.57141566", "0.5705294", "0.5701385", "0.57004064", "0.5698892", "0.5698892", "0.56954354", "0.56900144", "0.5681021", "0.56748474", "0.5670263", "0.5653945", "0.5650701", "0.5641955", "0.56400955", "0.56326437", "0.56289166", "0.5627217", "0.5624708", "0.5622745", "0.5621457", "0.56173337", "0.56109697", "0.5607023", "0.56039816", "0.55998784", "0.55945337", "0.5592221", "0.55878913", "0.5587748", "0.55877", "0.55862796", "0.5585121", "0.5582093", "0.55777943", "0.55741644", "0.5574027", "0.5572454", "0.55701655", "0.55677503", "0.55650806", "0.55609035", "0.5560399", "0.5558724", "0.5553375", "0.5553375", "0.5551264", "0.5545016", "0.5544452", "0.5538228", "0.55349195", "0.55298716", "0.5527297" ]
0.0
-1
auths not ready at this time The purpose of Dao method is to perform fetch operation of IPATestStage noun from database based on given noun id
public IPATestStage ipateststage_search_for_update(long id, IPUser user) throws Exception { log.setLevel(Level.INFO); log.info("ipateststage_search_for_update Dao started operation!"); try{ Query result = entityManager. createNativeQuery(search_for_update_IPATestStage,IPATestStage.class) .setParameter("id", id);; ArrayList<IPATestStage> IPATestStage_list = (ArrayList<IPATestStage>)result.getResultList(); if(IPATestStage_list == null){ log.error("ipateststage_search_for_update Dao throws exception :" + "no IPATestStage found" ); throw new Exception("no IPATestStage found"); } log.info("Object returned from ipateststage_search_for_update Dao method !"); return (IPATestStage) IPATestStage_list.get(0); }catch(Exception e){ //new Exception(e.toString()); // this needs to be changed log.error("ipateststage_search_for_update Dao throws exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public ArrayList<TestNoun> get_all_testnoun() throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"get_all_testnoun Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(get_all_TestNoun,TestNoun.class)\n\n;\n\n\t\t\tArrayList<TestNoun> TestNoun_list =\t(ArrayList<TestNoun>)result.getResultList();\n\n\t\t\tif(TestNoun_list .size() < 1){\n\n\t\t\tlog.error(\"get_all_testnoun Dao throws exception :\" + \"no TestNoun found\" );\n\t\t\t\treturn new ArrayList<TestNoun>();\n\t\t\t}\n\t\t\tlog.info(\"Object returned from get_all_testnoun Dao method !\");\n\t\t\treturn (ArrayList<TestNoun>) TestNoun_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"get_all_testnoun Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "@Transactional\n\tpublic TestNoun create_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"create_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(create_TestNoun)\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"created_by\", user == null ? 0:user.getId())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tint insertedId = query.executeUpdate();\n\t\t\t\t\tString lastIndex=\"select last_insert_id()\";\n\t\t\t\t\tQuery sql = entityManager.createNativeQuery(lastIndex);\n\t\t\t\t\tBigInteger new_id = (BigInteger) sql.getSingleResult();\n\t\t\t\t\tTestNoun.setId(new_id.longValue());\n\t\t\t\t\tSystem.out.println(\"create data---\"+insertedId);\n\n\t\t\tlog.info(\"Object returned from create_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (create_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public TestNoun testnoun_search_for_update(long id, LuUser user) throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"testnoun_search_for_update Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(search_for_update_TestNoun,TestNoun.class)\n\n\t\t\t.setParameter(\"id\", id);;\n\n\t\t\tArrayList<TestNoun> TestNoun_list =\t(ArrayList<TestNoun>)result.getResultList();\n\n\t\t\tif(TestNoun_list == null){\n\n\t\t\tlog.error(\"testnoun_search_for_update Dao throws exception :\" + \"no TestNoun found\" );\n\t\t\t}\n\t\t\tlog.info(\"Object returned from testnoun_search_for_update Dao method !\");\n\t\t\treturn (TestNoun) TestNoun_list.get(0);\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"testnoun_search_for_update Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "AnnouncementDO selectByPrimaryKey(Integer announceid);", "Ltsprojectpo selectByPrimaryKey(Long id);", "@Override\r\npublic int selectByPrimaryKey(Integer possalesdetailid) {\n\t\r\n\tPossalesdetail p= possalesdetail.selectByPrimaryKey(possalesdetailid);\r\n if(p.getPossalesdetailid()>0){\r\n \t\r\n \treturn 1;\r\n } else{\r\n\t return 0;\r\n }\r\n}", "@Transactional\n\tpublic String delete_testnoun(long id, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"delete_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(delete_TestNoun)\n\t\t\t.setParameter(\"id\", id);\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from delete_testnoun Dao method !\");\n\n\t\t\treturn \"{\\\"status\\\":\\\"success\\\"}\";\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (delete_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public Ruta findByPrimaryKey(RutaPk pk) throws RutaDaoException;", "public NominaPuesto findByPrimaryKey(NominaPuestoPk pk) throws NominaPuestoDaoException;", "@Override\r\n\tpublic snstatus queryByDocId(String sn) {\n\t\treturn (snstatus)super.getHibernateTemplate().get(snstatus.class, sn); \r\n\t}", "CommunityInform selectByPrimaryKey(String id);", "@Transactional\n\tpublic TestNoun update_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"update_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(update_TestNoun)\n\t\t\t.setParameter(\"id\", TestNoun.getId())\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from update_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (update_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "Tourst selectByPrimaryKey(String id);", "public void Found_project_from_DATABASE(int id){\n print_pro();\n// return project;\n }", "ProSchoolWare selectByPrimaryKey(String id);", "GoodsPo selectByPrimaryKey(Long id);", "Disproduct selectByPrimaryKey(String samId);", "@Override\r\npublic List<Possalesdetail> selectByExample(PossalesdetailExample example) {\n\treturn possalesdetail.selectByExample(example);\r\n}", "ActivityHongbaoPrize selectByPrimaryKey(Integer actPrizeId);", "IceApp selectByPrimaryKey(Long id);", "Disease selectByPrimaryKey(Integer id);", "HuoDong selectByPrimaryKey(Integer id);", "Article selectByPrimaryKey(String id);", "Caiwu selectByPrimaryKey(Integer id);", "CptDataStore selectByPrimaryKey(String id);", "TagData selectByPrimaryKey(Long tagid);", "Pet selectByPrimaryKey(Integer petid);", "Notice selectByPrimaryKey(Integer id);", "CmsVoteTitle selectByPrimaryKey(String id);", "O obtener(PK id) throws DAOException;", "Abum selectByPrimaryKey(String id);", "NjProductTaticsRelation selectByPrimaryKey(String id);", "PrhFree selectByPrimaryKey(Integer id);", "PublicDoctorNotice selectByPrimaryKey(String noticeId);", "SysCode selectByPrimaryKey(String id);", "Prueba selectByPrimaryKey(Integer id);", "MissionExecuteHistoryAwardPO selectByPrimaryKey(Long id);", "PrescriptionVerifyRecordDetail selectByPrimaryKey(String id);", "TCpySpouse selectByPrimaryKey(Integer id);", "Dress selectByPrimaryKey(Integer did);", "UserPonumberGoods selectByPrimaryKey(String ponumberGoodsId);", "Forumpost selectByPrimaryKey(Integer postid);", "SwipersDO selectByPrimaryKey(Integer id);", "public Tipo findByPrimaryKey(TipoPk pk) throws TipoDaoException;", "EtpBase selectByPrimaryKey(String id);", "ProcurementSource selectByPrimaryKey(Integer id);", "AccessModelEntity selectByPrimaryKey(String id);", "public NominaPuesto findByPrimaryKey(int idPuesto) throws NominaPuestoDaoException;", "organize_infoBean selectByPrimaryKey(Integer id);", "GpPubgPlayer selectByPrimaryKey(Long id);", "Nutrition selectByPrimaryKey(Integer nutritionid);", "SysNotice selectByPrimaryKey(Integer id);", "countrylanguage selectByPrimaryKey(countrylanguageKey key);", "OrderPO selectByPrimaryKey(Integer id);", "DictDoseUnit selectByPrimaryKey(Long dduId);", "private MapDBLabelToId() {\n\t\tproperties = new ProjectProperties(this.getClass());\n\n\t\tmap = db.getCollection(COLLECTION_NAME);\n\t\t// commitFrequency = properties.getInt(\"mapdb.commit\");\n\t}", "Kaiwa selectByPrimaryKey(String maht);", "SysId selectByPrimaryKey(String id);", "PmPost selectByPrimaryKey(String postId);", "AutoAssessDetailWithBLOBs selectByPrimaryKey(Long id);", "TDwBzzxBzflb selectByPrimaryKey(String objId);", "Depart selectByPrimaryKey(String id);", "Dormitory selectByPrimaryKey(Integer id);", "Basicinfo selectByPrimaryKey(String taxregcode);", "ArticleTag selectByPrimaryKey(Long articleTagId);", "ClinicalData selectByPrimaryKey(Long id);", "Dish selectByPrimaryKey(String id);", "public static void main(String[] args) throws SQLException {\n\t\n\t\tDocumentDAO y = new DocumentDAO();\n\tObservableList<Document> listeDoc= (new DocumentDAO()).findall();\n\tSystem.out.println(listeDoc.get(0));\n\t\t\n\t\t//VisiteurDAO v = new VisiteurDAO();\n\t//<Visiteur> idVisiteur = v.findById(\"a131\");\n\t\t\n\t\n\t\n\t}", "@Override\n\tpublic DbQueryStatus getSongTitleById(String songId) {\n\t\tif (songId == null){\n\t\t\tdbQueryStatus.setMessage(\"parameters are missing, please double check the parameters\");\n\t\t\tdbQueryStatus.setdbQueryExecResult(DbQueryExecResult.QUERY_ERROR_BAD_REQUEST);\n\t\t}\n\t\t// if there are some parameters missing\n\t\telse {\n\t\t\ttry {\n\t\t\t\tobjectId = new ObjectId(songId);\n\t\t\t} catch (Exception e) {\n\t\t\t\tdbQueryStatus.setMessage(\"The input songId is invalid\");\n\t\t\t\tdbQueryStatus.setdbQueryExecResult(DbQueryExecResult.QUERY_ERROR_BAD_REQUEST);\n\t\t\t\treturn dbQueryStatus;\n\t\t\t}\n\t\t\tHashtable queryPair = new Hashtable();\n\t\t\tqueryPair.put(\"_id\", objectId);\n\t\t\tDocument query = new Document(queryPair);\n\n\t\t\tMongoCursor<Document> cursor = collection.find(query).iterator();\n//\t\tSystem.out.println(\"set is \" + cursor.toString());\n\t\t\tif (cursor.hasNext()) {\n\t\t\t\tDocument songDocFound = cursor.next();\n\t\t\t\tSong songFound = converter.toSong(songDocFound);\n\n\t\t\t\tdbQueryStatus\n\t\t\t\t\t\t.setMessage(\"The song is successfully found in the database, title is returned\");\n\t\t\t\tdbQueryStatus.setdbQueryExecResult(DbQueryExecResult.QUERY_OK);\n\t\t\t\tdbQueryStatus.setData(songFound.getSongName());\n\t\t\t} else {\n\t\t\t\t//when object id is not existing int he database.\n\t\t\t\tdbQueryStatus.setMessage(\"The song with id given is not found in the database\");\n\t\t\t\tdbQueryStatus.setdbQueryExecResult(DbQueryExecResult.QUERY_ERROR_NOT_FOUND);\n\t\t\t\tdbQueryStatus.setData(null);\n\t\t\t}\n\t\t}\n\t\tSystem.out.println(dbQueryStatus.getMessage());\n\t\treturn dbQueryStatus;\n\t}", "@Override\n\tpublic TestPoEntity selectById(Integer pk) {\n\t\treturn null;\n\t}", "public DatiBancari findByPrimaryKey(DatiBancariPk pk) throws DatiBancariDaoException;", "YzStiveExplosion selectByPrimaryKey(Integer id);", "public Pojo.OneWord getById(String code){ \n Pojo.OneWord e=(Pojo.OneWord)template.get(Pojo.OneWord.class,code); \n return e; \n}", "public ArrayList<IPATestStage> search_ipateststage(String name) throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"search_ipateststage Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(search_IPATestStage,IPATestStage.class)\n\n\t\t\t.setParameter(\"name\", name.concat(\"%\"))\n;\n\n\t\t\tArrayList<IPATestStage> IPATestStage_list =\t(ArrayList<IPATestStage>)result.getResultList();\n\n\t\t\tif(IPATestStage_list == null){\n\n\t\t\tlog.error(\"search_ipateststage Dao throws exception :\" + \"null\" );\n\t\t\tthrow new Exception(\"null\");\n\t\t\t}\n\t\t\tlog.info(\"Object returned from search_ipateststage Dao method !\");\n\t\t\treturn (ArrayList<IPATestStage>) IPATestStage_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"search_ipateststage Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public void lookup(Id id, long version, Continuation command);", "@Override\r\npublic Detalle_pedido read(int id) {\n\treturn detalle_pedidoDao.read(id);\r\n}", "AlipayInfo selectByPrimaryKey(String id);", "LawPerson selectByPrimaryKey(Long personId);", "Thing selectByPrimaryKey(String thingid);", "public int findDidByDname(String Dname);", "CraftAdvReq selectByPrimaryKey(Integer id);", "Averia findAveriaById(Long id) throws BusinessException;", "MemberTag selectByPrimaryKey(Long id);", "PdfCodeTemporary selectByPrimaryKey(Integer id);", "public PosPay findPosPayById(Long id)throws DataAccessException;", "public ProjectIdea getProjectIdea(int id){\n //String sql = \"SELECT * FROM project_idea WHERE idea_id = ?\";\n try{\n ProjectIdea result = super.queryForId(id);\n return result;\n } catch(SQLException e){\n System.out.println(e.getMessage());\n }\n return null;\n }", "NjOrderWork2 selectByPrimaryKey(String id);", "List<PmKeyDbObj> selectByExample(PmKeyDbObjExample example);", "Procdef selectByPrimaryKey(String id);", "Yqbd selectByPrimaryKey(Integer id);", "ExamineApproveResult selectByPrimaryKey(Long id);", "DashboardGoods selectByPrimaryKey(Integer id);", "public DBEntry( SQL_Episode_II sql_epiII, String p_id ) {\n if ( ! Wattos.Utils.Strings.is_pdb_code( p_id ) ) {\n General.showError(\"in Classification.main found:\");\n General.showError(\"Given id [\"+p_id+\n \"] doesn't look like a valid pdb id.\");\n System.exit(1);\n }\n \n Retval ret = sql_epiII.getEntryByPDBId( p_id );\n if ( ret == null ) {\n General.showOutput(\"Failed to instantiate an instance of DBEntry from DB.\");\n System.exit(1);\n }\n entry_id = ret.entry_id;\n bmrb_id = ret.bmrb_id;\n pdb_id = ret.pdb_id;\n }", "OrderDetail selectByPrimaryKey(String detailId);", "CounselorBiographyTemp findById( Integer id ) ;", "@SuppressWarnings(\"unused\")\n@Repository\npublic interface DistrictRepository extends JpaRepository<District,Long> {\n\t\n\tpublic List<District> findByStateId(Long id);\n\t\n\t\n\t\n\n \n}", "public Tipo findByPrimaryKey(Integer idTipo) throws TipoDaoException;", "@Query(value = \"SELECT * FROM proveedor WHERE id=:id\", nativeQuery = true)\n public Proveedor obtenerPorId(@Param(\"id\") int id);", "public static void main(String [] args){\n\t\t\r\n\t\tEstadoDAO dao = new EstadoDAO();\r\n\t//\tdao.salvar(estado);\r\n\t\tList<Estado> estados= dao.list();\r\n\t\t \r\n\t\t for(Estado est: estados){\r\n\t\t System.out.println(est.getEstado());\r\n\t\t \r\n\t\t\t\t\r\n\r\n\t\t \r\n\t\t // CidadeDAO dao = new CidadeDAO();\r\n\t\t // cidades = dao.buscartudo();\r\n\t\t // for(Cidade cid: cidades){\r\n\t\t // System.out.println(cid.getNome_cidade());\r\n\t\t }\r\n\r\n\r\n\r\n\r\n\r\n\r\n\t}", "Goods selectByPrimaryKey(String goodsId);" ]
[ "0.5795813", "0.57545054", "0.575171", "0.5700125", "0.55816436", "0.55574197", "0.5504387", "0.54649216", "0.5434663", "0.5426015", "0.54259264", "0.5423358", "0.5374122", "0.5341946", "0.53376454", "0.5335463", "0.53214884", "0.5308639", "0.5301778", "0.5290744", "0.5282068", "0.52688646", "0.5260642", "0.5251697", "0.5245369", "0.5225035", "0.5219388", "0.5207178", "0.5188475", "0.51750225", "0.5173143", "0.5164093", "0.5163071", "0.5148205", "0.5145339", "0.51442164", "0.51429033", "0.51407665", "0.5137308", "0.51275384", "0.5122576", "0.51223296", "0.51204103", "0.51081353", "0.51010966", "0.5083323", "0.50808847", "0.5077934", "0.5071445", "0.50623393", "0.505771", "0.5050737", "0.5042913", "0.5042444", "0.5040761", "0.5039872", "0.50397915", "0.5037943", "0.50367945", "0.50267106", "0.5023657", "0.5021551", "0.5017487", "0.50168604", "0.50098896", "0.50027347", "0.49947572", "0.4993226", "0.4978743", "0.497762", "0.4966583", "0.49564976", "0.49540704", "0.4950002", "0.49485704", "0.49454683", "0.49434793", "0.4941278", "0.49404758", "0.49371326", "0.4935842", "0.4934743", "0.49340963", "0.49299237", "0.49296403", "0.49213818", "0.4919823", "0.4913774", "0.49116164", "0.49107158", "0.4909218", "0.4909147", "0.49042836", "0.48974717", "0.48955306", "0.48808348", "0.48789048", "0.48665354", "0.48643965", "0.4859699" ]
0.49973497
66
auths not ready at this time The purpose of Dao method is to get list of IPATestStage noun from database
public ArrayList<IPATestStage> get_all_ipateststage() throws Exception { log.setLevel(Level.INFO); log.info("get_all_ipateststage Dao started operation!"); try{ Query result = entityManager. createNativeQuery(get_all_IPATestStage,IPATestStage.class) ; ArrayList<IPATestStage> IPATestStage_list = (ArrayList<IPATestStage>)result.getResultList(); if(IPATestStage_list .size() < 1){ log.error("get_all_ipateststage Dao throws exception :" + "no IPATestStage found" ); throw new Exception("no IPATestStage found"); } log.info("Object returned from get_all_ipateststage Dao method !"); return (ArrayList<IPATestStage>) IPATestStage_list; }catch(Exception e){ //new Exception(e.toString()); // this needs to be changed log.error("get_all_ipateststage Dao throws exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public ArrayList<TestNoun> get_all_testnoun() throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"get_all_testnoun Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(get_all_TestNoun,TestNoun.class)\n\n;\n\n\t\t\tArrayList<TestNoun> TestNoun_list =\t(ArrayList<TestNoun>)result.getResultList();\n\n\t\t\tif(TestNoun_list .size() < 1){\n\n\t\t\tlog.error(\"get_all_testnoun Dao throws exception :\" + \"no TestNoun found\" );\n\t\t\t\treturn new ArrayList<TestNoun>();\n\t\t\t}\n\t\t\tlog.info(\"Object returned from get_all_testnoun Dao method !\");\n\t\t\treturn (ArrayList<TestNoun>) TestNoun_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"get_all_testnoun Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public ArrayList<IPATestStage> search_ipateststage(String name) throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"search_ipateststage Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(search_IPATestStage,IPATestStage.class)\n\n\t\t\t.setParameter(\"name\", name.concat(\"%\"))\n;\n\n\t\t\tArrayList<IPATestStage> IPATestStage_list =\t(ArrayList<IPATestStage>)result.getResultList();\n\n\t\t\tif(IPATestStage_list == null){\n\n\t\t\tlog.error(\"search_ipateststage Dao throws exception :\" + \"null\" );\n\t\t\tthrow new Exception(\"null\");\n\t\t\t}\n\t\t\tlog.info(\"Object returned from search_ipateststage Dao method !\");\n\t\t\treturn (ArrayList<IPATestStage>) IPATestStage_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"search_ipateststage Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public void listarProvincia() {\n provincias = JPAFactoryDAO.getFactory().getProvinciaDAO().find();\n// for(int i=0;i<provincias.size();i++ ){\n// System.out.println(\"lista:\"+provincias.get(i).getNombreprovincia());\n// }\n }", "private void getPlayerList(){\r\n\r\n PlayerDAO playerDAO = new PlayerDAO(Statistics.this);\r\n players = playerDAO.readListofPlayerNameswDefaultFirst();\r\n\r\n }", "@Override\r\npublic List<Possalesdetail> selectByExample(PossalesdetailExample example) {\n\treturn possalesdetail.selectByExample(example);\r\n}", "private static List<TextAnnotation> getInstancesFromDb(Configuration runConfig) {\n String datasetName = runConfig.dataset;\n POSReader posReader = new POSReader();\n System.out.println(\"Retrieving instances from db\");\n List<TextAnnotation> TextAnnotations = posReader.getTextAnnotationsFromDB(runConfig.dataset);\n return TextAnnotations;\n }", "@Query(value = \"SELECT * FROM aluno a WHERE a.situacao = true ORDER BY ID\", nativeQuery = true)\n List<Aluno> findAlunosAprovados();", "public List<PokemonEntity> findAll() {\n LOGGER.log(Level.INFO, \"Consultando todas los trayectos\");\n // Se crea un query para buscar todas las ciudades en la base de datos.\n TypedQuery query = em.createQuery(\"select u from PokemonEntity u\", PokemonEntity.class);\n // Note que en el query se hace uso del método getResultList() que obtiene una lista de ciudades.\n return query.getResultList();\n}", "public List<VerbPhrase> getVpList(){\n\t\tSet<NounPhrase> entitySet = this.getEntConsiderPass(\"O\");\n\t\tList<VerbPhrase> vpList = new ArrayList<VerbPhrase>();\n\t\t\n\t\tfor(NounPhrase object : entitySet){\t\t\n\t\t\t//vpList.add(new VerbPhrase(this.getActionStr(), object));\n\t\t\tvpList.add(new VerbPhrase(this.action, object));\n\t\t}\t\t\n\t\treturn vpList;\n\t}", "public static List<Task> getTaskFromDb() {\n List<Task> taskList = new ArrayList<>();\n try {\n // taskList = Task.listAll(Task.class);\n taskList= Select.from(Task.class).orderBy(\"due_date Desc\").where(\"status=?\", new String[] {\"0\"}).list();\n } catch (Exception e) {\n e.printStackTrace();\n\n }\n return taskList;\n\n }", "@Override\n public List<Paciente> listar(){\n EntityManagerFactory factory = Persistence.createEntityManagerFactory(\"vesaliusPU\"); \n EntityManager em = factory.createEntityManager();\n List<Paciente> listaPaciente = em.createQuery(\"SELECT pac FROM Paciente pac\").getResultList(); \n em.close();\n factory.close();\n return (listaPaciente);\n }", "@Override\n public List<Seq> getAll() {\n Connection conn = null;\n Statement stmt = null;\n List<Seq> listSeqs = new ArrayList<>();\n\n try {\n String url = \"jdbc:sqlite:src\\\\database\\\\AT2_Mobile.db\";\n conn = DriverManager.getConnection(url);\n stmt = conn.createStatement();\n ProcessesDAO pdao = new ProcessesDAO();\n String sql = \"select * from seq;\";\n ResultSet rs = stmt.executeQuery(sql);\n\n while (rs.next()) {\n\n Seq seq = new Seq(rs.getInt(\"id\"), pdao.getbyidentifier(rs.getString(\"identifier\")), rs.getInt(\"seq_number\"));\n listSeqs.add(seq);\n }\n rs.close();\n\n } catch (SQLException e) {\n System.out.println(e.getMessage());\n } finally {\n try {\n if (conn != null) {\n conn.close();\n }\n } catch (SQLException ex) {\n System.out.println(ex.getMessage());\n }\n }\n return listSeqs;\n }", "private static void getListTest() {\n\t\tList<CartVo> list=new CartDao().getList();\r\n\t\t\r\n\t\tfor(CartVo cartVo : list) {\r\n\t\t\tSystem.out.println(cartVo);\r\n\t\t}\r\n\t}", "java.util.List<hr.domain.ResumeDBOuterClass.Experience> \n getExperiencesList();", "public List<DIS001> findAll_DIS001();", "@Override\n\tpublic List<PersonVO> test() {\n\t\tSystem.out.println(\"Service 접근\");\n\t\treturn mongoDAO.test();\n\t}", "public Cursor getallsessment(String stageid)\n {\n \ttry\n \t{\n \t\tString sql=\"SELECT * FROM assessment where stageId='\"+stageid+\"'\";\n \t\t\n \t\tCursor mCur=mDb.rawQuery(sql, null);\n \t\tif(mCur!=null)\n \t\t{\n \t\t\tmCur.moveToNext();\n \t\t}\n \t\treturn mCur;\n \t}\n \tcatch(SQLException mSQLException)\n \t{\n \t\tLog.e(TAG, \"getTestData >>\"+ mSQLException.toString());\n \t\tthrow mSQLException;\n \t}\n }", "public void listNens() {\n\t\t\tEntityManager em = emf.createEntityManager();\n\t\t\tem.getTransaction().begin();\n\t\t\tList<Nen> result = em.createQuery(\"from nen\", Nen.class)\n\t\t\t\t\t.getResultList();\n\t\t\tfor (Nen a : result) {\n\t\t\t\tSystem.out.println(a.toString());\n\t\t\t}\n\t\t\tem.getTransaction().commit();\n\t\t\tem.close();\t\n\t\t}", "public ArrayList<Poentity> get_all_poentity() throws Exception {\n\n \t\t log.setLevel(Level.INFO);\n\t log.info(\" service operation started !\");\n\n\t\ttry{\n\t\t\tArrayList<Poentity> Poentity_list;\n\n\t\t\tPoentity_list = Poentity_Activity_dao.get_all_poentity();\n\n \t\t\tlog.info(\" Object returned from service method !\");\n\t\t\treturn Poentity_list;\n\n\t\t}catch(Exception e){\n\n\t\t\tSystem.out.println(\"ServiceException: \" + e.toString());\n\t\t\tlog.error(\" service throws exception : \"+ e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public static ArrayList<String> getSentence(BasicDBObject dbObject) {\n\n\t\tArrayList<String> list = new ArrayList<String>();\n\t\tfor (Object temp : (BasicDBList) dbObject.get(\"tokens\")) {\n\t\t\tBasicDBObject token = (BasicDBObject) temp;\n\t\t\tString word = token.getString(\"lemma\");\n\t\t\tlist.add(word);\n\t\t}\n\t\treturn list;\n\n\t}", "public java.util.List<PlanoSaude> findAll();", "public String[] getVenueList() {\n Connection con = null;\n PreparedStatement st = null;\n ResultSet rs = null;\n Vector<String> list = new Vector<String>();\n String[] result = null;\n try {\n //obtain the database connection by calling getConn()\n con = getConn();\n \n //create the PreparedStatement from the Connection object by calling prepareStatement\n //method, passing it the sql \n st = con.prepareStatement(\"select * from Venue\");\n \n //Calls executeQuery and the resulting data is returned in the resultset\n rs = st.executeQuery();\n \n //loop through the result set and save the data in the datamodel objects\n while (rs.next()){\n //System.out.println(\"inside while....\");\n list.add(rs.getString(\"id\") + \",\" + rs.getString(\"NAME\"));\n \n }\n result = new String[list.size()];\n for (int i = 0 ; i< list.size() ; i++){\n result[i] = list.get(i);\n \n }\n }\n catch (SQLException e){\n \n }\n \n //close the resultset,preparedstatement and connection to relase resources \n if (rs != null){\n try{\n rs.close();\n rs = null;\n }\n catch (SQLException e){\n \n }\n }\n if (st != null){\n try{\n st.close();\n st = null;\n }\n catch (SQLException e){\n \n }\n }\n \n if (con != null){\n try{\n con.close();\n con = null;\n }\n catch (SQLException e){\n \n }\n }\n \n return result;\n }", "private void getDepartamentos() {\n try{\n EntityManagerFactory emf = Persistence.createEntityManagerFactory(\"ServiceQualificationPU\");\n EntityManager em = emf.createEntityManager();\n\n\n String jpql =\"SELECT d FROM Departamento d \"\n + \"WHERE d.estado = 'a'\";\n\n Query query = em.createQuery(jpql);\n List<Departamento> listDepartamentos = query.getResultList();\n ArrayList<Departamento> arrayListDepartamentos = new ArrayList<>();\n for(Departamento d: listDepartamentos){\n arrayListDepartamentos.add(d);\n }\n this.Listdepartamentos = arrayListDepartamentos;\n em.close();\n emf.close();\n }\n catch(Exception e){\n System.out.println(\"ERROR: \"+e);\n this.Error = \"ERROR: \"+e;\n }\n }", "private void consultartiposincidentes() {\n\n db= con.getWritableDatabase();\n TipoIncidente clase_tipo_incidente= null;\n tipoincidentelist= new ArrayList<TipoIncidente>();\n //CONSULTA\n Cursor cursor=db.rawQuery(\"select codigo_incidente,tipo_incidente from \" +Utilitario.TABLE_TIPO_INCIDENTE,null);\n\n while (cursor.moveToNext()){\n clase_tipo_incidente=new TipoIncidente();\n clase_tipo_incidente.setCodigo(cursor.getInt(0));\n clase_tipo_incidente.setDescripcion(cursor.getString(1));\n\n Log.i(\"id\",clase_tipo_incidente.getCodigo().toString());\n Log.i(\"desc\",clase_tipo_incidente.getDescripcion());\n\n tipoincidentelist.add(clase_tipo_incidente);\n\n }\n llenarspinner();\n db.close();\n }", "public List getAllStu();", "List<Plaza> consultarPlazas();", "public ArrayList<String> consultar(){\n PreparedStatement ps = null;\n ResultSet rs = null;\n Connection con = getConexion();\n PlanDeEstudio plan = new PlanDeEstudio();\n ArrayList<String> planes = new ArrayList<>();\n \n String sql = \"SELECT * FROM plan_estudio\";\n \n try{\n ps = con.prepareStatement(sql);\n rs = ps.executeQuery();\n \n while (rs.next()) {\n plan.setiD(Integer.parseInt((rs.getString(\"id_plan_estudio\"))));\n planes.add(Integer.toString((plan.getiD())));\n }\n return planes;\n \n }catch (SQLException e){\n System.err.println(e);\n return planes;\n \n } finally {\n try {\n con.close();\n } catch (SQLException e){\n System.err.println(e);\n }\n }\n }", "List<Videogioco> findAllVideogioco();", "public static void main(String [] args){\n\t\t\r\n\t\tEstadoDAO dao = new EstadoDAO();\r\n\t//\tdao.salvar(estado);\r\n\t\tList<Estado> estados= dao.list();\r\n\t\t \r\n\t\t for(Estado est: estados){\r\n\t\t System.out.println(est.getEstado());\r\n\t\t \r\n\t\t\t\t\r\n\r\n\t\t \r\n\t\t // CidadeDAO dao = new CidadeDAO();\r\n\t\t // cidades = dao.buscartudo();\r\n\t\t // for(Cidade cid: cidades){\r\n\t\t // System.out.println(cid.getNome_cidade());\r\n\t\t }\r\n\r\n\r\n\r\n\r\n\r\n\r\n\t}", "public void listar()\n\t{\n\t\tdatabase.list().forEach(\n\t\t\t(entidade) -> { IO.println(entidade.print() + \"\\n\"); }\n\t\t);\n\t}", "public static List<SqlRow> findAll() {\n\n try{\n List<SqlRow> queryFindAll = Ebean.createSqlQuery(\"SELECT * FROM pub_infoapi;\")\n .findList();\n return queryFindAll;\n }catch(Exception e){\n e.printStackTrace();\n return null;\n }\n }", "public String listar() {\n DocumentoVinculadoDAO documentoVinculadoDAO = new DocumentoVinculadoDAO();\n lista = documentoVinculadoDAO.listarStatus(1);\n return \"listar\";\n\n }", "public ArrayList<AVPLeadSource> get_all_avpleadsource() throws Exception {\n\n \t\t log.setLevel(Level.INFO);\n\t log.info(\" service operation started !\");\n\n\t\ttry{\n\t\t\tArrayList<AVPLeadSource> AVPLeadSource_list;\n\n\t\t\tAVPLeadSource_list = AVPLeadSource_dao.get_all_avpleadsource();\n\n \t\t\tlog.info(\" Object returned from service method !\");\n\t\t\treturn AVPLeadSource_list;\n\n\t\t}catch(Exception e){\n\n\t\t\tSystem.out.println(\"ServiceException: \" + e.toString());\n\t\t\tlog.error(\" service throws exception : \"+ e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "@GetMapping(\"/findAll\")\n public List<LabTest> findAll(){\n return labTestService.getLabTests();\n }", "public List<Tipousr> findAllTipos(){\n\t\t List<Tipousr> listado;\n\t\t Query q;\n\t\t em.getTransaction().begin();\n\t\t q=em.createQuery(\"SELECT u FROM Tipousr u ORDER BY u.idTipousr\");\n\t\t listado= q.getResultList();\n\t\t em.getTransaction().commit();\n\t\t return listado;\n\t\t \n\t\t}", "public ArrayList<Info_laboral> findAll(){\n ConexionBD con = new ConexionBD();\n Connection c = con.conOracle();\n\n ArrayList<Info_laboral> eeg = new ArrayList();\n\n try{\n ResultSet gs = con.ejecutaCon(\" Select * from Info_laboral\"); \n while(gs.next()){\n \n Estudios_Egresado ee=new Estudios_Egresado();\n Info_laboral i =new Info_laboral();\n Egresado eg = new Egresado();\n Estudios es = new Estudios();\n \n i.setId(gs.getInt(1));\n i.setJefe(gs.getString(2));\n i.setCargo(gs.getString(3));\n i.setFuncion(gs.getString(4));\n i.setFecha_ini(gs.getDate(5));\n i.setFecha_fin(gs.getDate(6));\n i.setMotivo_retiro(gs.getString(7));\n eg.setId(gs.getLong(8));\n i.setId_egresado(eg);\n i.setPerfil(gs.getString(9));\n \n eeg.add(i);\n }\n }catch(SQLException e){\n System.out.println(\"error \"+e);\n return null;\n }\n return eeg;\n }", "@Query(\"select * from test order by testId\")\n LiveData<List<Test>> getAllTests();", "ArrayList<News> findByTitle(String title) throws DAOException, ConnectionPoolDataSourceException;", "private static void getListTest(int no) {\n\t\tList<CartVo> list=new CartDao().getList(no);\r\n\t\t\r\n\t\tfor(CartVo cartVo : list) {\r\n\t\t\tSystem.out.println(cartVo);\r\n\t\t}\r\n\t}", "@Override\n\tpublic List<Paciente> listar() {\n\t\treturn dao.findAll();\n\t}", "List<Ltsprojectpo> selectByExample(LtsprojectpoExample example);", "@Query(\"Select * from Asignatura\")\n LiveData<List<Asignatura>> obtenerAsignaturas();", "public static ArrayList<Song> getAll() {\n ArrayList<Song> songs = new ArrayList<>();\n try {\n Class.forName(\"com.mysql.jdbc.Driver\");\n conn = DriverManager.getConnection(\"jdbc:mysql://\" + host + \"/\" + db + \"?\" + \"user=\" + user + \"&password=\" + psw );\n\n songStatement = conn.createStatement();\n songResultSet = songStatement.executeQuery(\"SELECT * FROM spotify.track WHERE annotated = 0 LIMIT 0, 25\");\n\n songs = createSongs(songResultSet);\n } catch (Exception e) {\n e.printStackTrace();\n } finally {\n close();\n }\n\n return songs;\n }", "public NominaPuesto[] findAll() throws NominaPuestoDaoException;", "@Override\r\n\tpublic List<AgentDBInfoVO> selectDBInfoList(){\n\t\treturn sqlSession.getMapper(CollectMapper.class).selectDBInfoList();\r\n\t}", "@Override\n public List<Venda> listar() {\n String sql = \"SELECT v FROM venda v\";\n TypedQuery<Venda> query = em.createQuery(sql, Venda.class);\n List<Venda> resultList = query.getResultList();\n\n return resultList;\n }", "public List queryTest() {\n\t\tList list = null;\n\t\tthis.init();\n\t\t try {\n\t\t\t list= sqlMap.queryForList(\"getAllTest\");\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} \n\t\treturn list;\n\t\t\n\t}", "java.util.List<hr.domain.ResumeDBOuterClass.Resume> \n getResumesList();", "public ArrayList<Test1> get_all_test1() throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"get_all_test1 Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(get_all_Test1,Test1.class)\n\n;\n\n\t\t\tArrayList<Test1> Test1_list =\t(ArrayList<Test1>)result.getResultList();\n\n\t\t\tif(Test1_list .size() < 1){\n\n\t\t\tlog.error(\"get_all_test1 Dao throws exception :\" + \"no Test1 found\" );\n\t\t\t\treturn new ArrayList<Test1>();\n\t\t\t}\n\t\t\tlog.info(\"Object returned from get_all_test1 Dao method !\");\n\t\t\treturn (ArrayList<Test1>) Test1_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"get_all_test1 Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "List<ActivityHongbaoPrize> selectByExample(ActivityHongbaoPrizeExample example);", "private void ListForeignDatei () {\n\n ForeignDataDbSource foreignDataDbSource = new ForeignDataDbSource();\n\n List<ForeignData> foreignDataList= foreignDataDbSource.getAllForeignData();\n Log.d(LOG_TAG,\"=============================================================\");\n\n for (int i= 0; i < foreignDataList.size(); i++){\n String output = \"Foreign_ID_Node: \"+ foreignDataList.get(i).getUid() +\n //\"\\n Status: \"+ foreignDataList.get(i).isChecked() +\n \"\\n Foto ID: \"+ foreignDataList.get(i).getFotoId() +\n \"\\n Punkt X: \"+ foreignDataList.get(i).getPunktX() +\n \"\\n Punkt Y: \"+ foreignDataList.get(i).getPunktY() +\n \"\\n IP: \"+ foreignDataList.get(i).getForeignIp() ;\n\n Log.d(LOG_TAG, output);\n }\n Log.d(LOG_TAG,\"=============================================================\");\n }", "List<Videogioco> retriveByPiattaforma(String piattaforma);", "@Override\r\n\tpublic List<Post> latastPosts(int bankuaihao) {\n\t\tpostDao=new PostDaoImpl(TransactionManager.connection);\r\n\t\tList<Post> list=new ArrayList<Post>();\r\n\t\treturn postDao.latastPosts(bankuaihao);\r\n\t\t\r\n\t}", "List<ResumeKpiPO> selectByExample(ResumeKpiPOExample example);", "@Override\r\n\tpublic List<SubstageDocument> getAll() throws Exception {\n\t\treturn null;\r\n\t}", "List<ParqueaderoEntidad> listar();", "public List<Player> selectByNationality(String nationality) throws Exception;", "List<PmKeyDbObj> selectByExample(PmKeyDbObjExample example);", "public List<StatusDemande> getStatusDemandes(){\n return statusDemandeRepository.findAll();\n }", "@Query(\"SELECT * from english_word ORDER BY word ASC limit 300\")\n List<StoredEnglishWord> findAllWords();", "public String showAnnouncements() {\n String output = \"\";\n\n // Get\n List<Models.Announcement> fromInstitution = em.createNativeQuery(\"select a.* from announcement a, institution i, institutionparticipant ipa, participant p where a.institutioncode = i.institutioncode and i.institutioncode = ipa.institutioncode and ipa.participantid = p.participantid and p.userid = ? order by dateannounced desc fetch first 3 rows only\", Models.Announcement.class).setParameter(1, user.getUserid()).getResultList();\n List<Models.Announcement> fromProgramme = em.createNativeQuery(\"select a.* from announcement a, programme pg, programmeparticipant ppa, participant p where a.programmecode = pg.programmecode and pg.programmecode = ppa.programmecode and ppa.participantid = p.participantid and p.userid = ? order by dateannounced desc fetch first 3 rows only\", Models.Announcement.class).setParameter(1, user.getUserid()).getResultList();\n List<Models.Announcement> fromCourse = em.createNativeQuery(\"select a.* from announcement a, course c, courseparticipant cpa, participant p where a.coursecode = c.coursecode and c.coursecode = cpa.coursecode and cpa.participantid = p.participantid and p.userid = ? order by dateannounced desc fetch first 3 rows only\", Models.Announcement.class).setParameter(1, user.getUserid()).getResultList();\n List<Models.Announcement> fromClass = em.createNativeQuery(\"select a.* from announcement a, class c, classparticipant cpa, participant p where a.classid = c.classid and c.classid = cpa.classid and cpa.participantid = p.participantid and p.userid = ? order by dateannounced desc fetch first 3 rows only\", Models.Announcement.class).setParameter(1, user.getUserid()).getResultList();\n\n return displayAnnouncements(fromInstitution, fromProgramme, fromCourse, fromClass);\n }", "@Override\n public ArrayList<Propiedad> getPropiedadesAgente(String pId) throws SQLException {\n ArrayList<Propiedad> resultado = new ArrayList<Propiedad>();\n resultado = (ArrayList<Propiedad>) bdPropiedad.selectQuery(\"SELECT * FROM PROPIEDAD WHERE ID_AGENTE \"\n + \"= '\" + pId + \"'\");\n return resultado;\n }", "List<ShipmentInfoPODDTO> findAll();", "public LiveData<List<Adoption>> getAdoptions(Context ctx)\n {\n if(adoptions == null)\n {\n ProjectDatabase db = db = Room.databaseBuilder(ctx,\n ProjectDatabase.class,\n \"projectDB\").build();\n\n adoptions = db.adoptionDao().getAll();\n }\n return adoptions;\n }", "private void getPTs(){\n mPyTs = estudioAdapter.getListaPesoyTallasSinEnviar();\n //ca.close();\n }", "private void getAllNewsFromDatabase() {\n new GetAllNewsAsyncTask(newsDao).execute(newsList);\n }", "public ArrayList<String> getAllDepartmentsByYuanxi(String yuanxi)\r\n/* 70: */ {\r\n/* 71: 60 */ String sql = \"select department from t_department where yuanxi = '\"+yuanxi+\"' \";\r\n/* 72: */ \r\n/* 73: 62 */ ArrayList<String> deptNameArr = new ArrayList();\r\n/* 74: */ try\r\n/* 75: */ {\r\n/* 76: 64 */ this.ct = new ConnDb().getConn();\r\n/* 77: 65 */ this.ps = this.ct.prepareStatement(sql);\r\n/* 78: 66 */ this.rs = this.ps.executeQuery();\r\n/* 79: 67 */ while (this.rs.next())\r\n/* 80: */ {\r\n/* 81: 68 */ String deptName = new String(this.rs.getString(1));\r\n/* 82: 69 */ deptNameArr.add(deptName);\r\n/* 83: */ }\r\n/* 84: 71 */ return deptNameArr;\r\n/* 85: */ }\r\n/* 86: */ catch (Exception e)\r\n/* 87: */ {\r\n/* 88: 74 */ e.printStackTrace();\r\n/* 89: 75 */ return null;\r\n/* 90: */ }\r\n/* 91: */ finally\r\n/* 92: */ {\r\n/* 93: 77 */ closeSourse();\r\n/* 94: */ }\r\n/* 95: */ }", "public ArrayList<ModelAprendizagemTeorica> getListaAprendizagemTeoricaDAO(){\n ArrayList<ModelAprendizagemTeorica> listamodelAprendizagemTeorica = new ArrayList();\n ModelAprendizagemTeorica modelAprendizagemTeorica = new ModelAprendizagemTeorica();\n try {\n this.conectar();\n this.executarSQL(\n \"SELECT \"\n + \"id,\"\n + \"descricao,\"\n + \"texto\"\n + \" FROM\"\n + \" aprendizagem_teorica\"\n + \";\"\n );\n\n while(this.getResultSet().next()){\n modelAprendizagemTeorica = new ModelAprendizagemTeorica();\n modelAprendizagemTeorica.setId(this.getResultSet().getInt(1));\n modelAprendizagemTeorica.setDescricao(this.getResultSet().getString(2));\n modelAprendizagemTeorica.setTexto(this.getResultSet().getString(3));\n listamodelAprendizagemTeorica.add(modelAprendizagemTeorica);\n }\n }catch(Exception e){\n e.printStackTrace();\n }finally{\n this.fecharConexao();\n }\n return listamodelAprendizagemTeorica;\n }", "@RequestMapping(value = \"/obtenerVeredas\", method = RequestMethod.GET)\n\tpublic Iterable<Vereda> obtenerListaVeredas() {\n\t\treturn veredaRepository.findAll();\n\t\t//return JsonManager.toJson(veredaRepository.findAll());\n\t}", "List<AnswerList> findAllAnsList();", "@Test\n public void test2(){\n\n List<FitActivity> upper = fitActivityRepository.findAllByBodyPart(\"Upper\");\n for (FitActivity fitActivity : upper) {\n System.out.println(fitActivity.getName());\n\n }\n\n }", "List<NovedadAdapter> getAll();", "public void findallstudentservice() {\n\t\t dao.findallstudent();\r\n\t\t\r\n\t}", "public List<Poruke> getAllPoruke(){\r\n return porukeBeanLocal.getAllPoruke();\r\n }", "public List<String> getAllProcessNamesFromDatabase() \r\n throws ServiceFailureException;", "public List<PrioritaetEntity> findAll() throws Exception;", "public abstract List<TipoActividad> getTiposActividad() throws PersistenceException, ClassNotFoundException;", "private static final String FIND_ALL() {\r\n\t\treturn \"from Shipping3VO vo \";\r\n\t}", "public ArrayList<Department> getAllDep(String yuanxi)\r\n/* 16: */ {\r\n/* 17: 17 */ String sql = \"select * from t_department where yuanxi= '\" + yuanxi + \"'\";\r\n/* 18: 18 */ ArrayList<Department> al = new ArrayList();\r\n/* 19: 19 */ Department d = null;\r\n/* 20: */ try\r\n/* 21: */ {\r\n/* 22: 21 */ this.ct = new ConnDb().getConn();\r\n/* 23: 22 */ this.ps = this.ct.prepareStatement(sql);\r\n/* 24: 23 */ this.rs = this.ps.executeQuery();\r\n/* 25: 24 */ while (this.rs.next())\r\n/* 26: */ {\r\n/* 27: 25 */ d = new Department(this.rs.getInt(1), this.rs.getString(2));\r\n/* 28: 26 */ al.add(d);\r\n/* 29: */ }\r\n/* 30: 28 */ return al;\r\n/* 31: */ }\r\n/* 32: */ catch (Exception e)\r\n/* 33: */ {\r\n/* 34: 31 */ e.printStackTrace();\r\n/* 35: 32 */ return null;\r\n/* 36: */ }\r\n/* 37: */ finally\r\n/* 38: */ {\r\n/* 39: 34 */ closeSourse();\r\n/* 40: */ }\r\n/* 41: */ }", "public List<Pojo.OneWord> getOneWord(){ \n List<Pojo.OneWord> list=new ArrayList<Pojo.OneWord>(); \n list=template.loadAll(Pojo.OneWord.class); \n return list; \n}", "public Cursor getallchecklistindex(String stageid)\n {\n \ttry\n \t{\n \t\tString sql=\"select checklist.Id,checklist.checknum,checklist.name,checklist.rpl from checklistindex inner join checklist on checklistindex.checknum=checklist.checknum where checklistindex.stageid='\"+stageid+\"' GROUP BY checklistindex.checknum\";\n \t\t\n \t\tCursor mCur=mDb.rawQuery(sql, null);\n \t\tif(mCur!=null)\n \t\t{\n \t\t\tmCur.moveToNext();\n \t\t}\n \t\treturn mCur;\n \t}\n \tcatch(SQLException mSQLException)\n \t{\n \t\tLog.e(TAG, \"getTestData >>\"+ mSQLException.toString());\n \t\tthrow mSQLException;\n \t}\n }", "public List<Sports> getAllSportsService() {\n\t\tList<Sports> list=new ArrayList<>();\n\t\tlist=(List<Sports>)repository.findAll();\n\t\tif(list.size()<1)\n\t\t\tthrow new RecordNotFoundException(\"No Sports present in the table Sports\");\n\t\tlogger.info(\"Size of the list after fetching all the records= \"+list.size());\n\t\treturn list;\n\t\t\n\t}", "public List<Status> selectAllStatuts(){\n\treturn statusDao.findAll();\n\t}", "@Override\r\n public List<Anggota> getAll() {\r\n List<Anggota> datas = new ArrayList<>();\r\n String query = \"SELECT *From Anggota\";\r\n try {\r\n\r\n PreparedStatement preparedStatement = connection.prepareStatement(query);\r\n ResultSet rs = preparedStatement.executeQuery();\r\n\r\n while (rs.next()) {\r\n Anggota anggota = new Anggota();\r\n anggota.setKdAnggota(rs.getString(1));\r\n anggota.setNmAnggota(rs.getString(2));\r\n anggota.setTelepon(rs.getString(3));\r\n anggota.setAlamat(rs.getString(4));\r\n datas.add(anggota);\r\n }\r\n\r\n } catch (SQLException ex) {\r\n Logger.getLogger(AnggotaDAO.class.getName()).log(Level.SEVERE, null, ex);\r\n }\r\n\r\n return datas;\r\n\r\n }", "public abstract List<TipoActividad> getTiposActividadAdm() throws PersistenceException, ClassNotFoundException;", "@Override\n public ArrayList<Zona> list(String description) {\n ArrayList<Zona> res = new ArrayList<>();\n conn = new Connector();\n conn.conectar();\n con = conn.getConexion();\n String list = \"SELECT id, name \"\n + \"FROM zone \"\n + \"WHERE concat(id,' ',name) like '%\"\n + description + \"%' \"\n + \"ORDER BY id DESC\";\n try {\n st = con.createStatement();\n \n rt = st.executeQuery(list);\n //mientras rt tenga datos se iterara\n while (rt.next()) {\n //accedes en el orden q espesificaste en el select rt.getInt(1) = id_user;\n res.add(new Zona(rt.getInt(1), rt.getString(2)));\n }\n System.out.println(\"Lista de zonas recuperadas correctamente\");\n conn.desconectar();\n } catch (SQLException ex) {\n JOptionPane.showMessageDialog(null, ex);\n }\n return res;\n }", "List<Province> selectByExample(ProvinceExample example);", "public void listArticles() {\n\t\tSystem.out.println(\"\\nArticles llegits desde la base de dades\");\n\n\t\tObjectSet<Article> articles = db.query(Article.class);\n\t\tarticles.stream()\n\t\t\t.forEach(System.out::println);\n\t}", "@Override\n\tpublic List<NewsVO> getAll() {\n\t\tList<NewsVO> list = new ArrayList<NewsVO>();\n\t\tNewsVO newsVO = null;\n\n\t\tConnection con = null;\n\t\tPreparedStatement pstmt = null;\n\t\tResultSet rs = null;\n\n\t\ttry {\n\n\t\t\tClass.forName(driver);\n\t\t\tcon = DriverManager.getConnection(url, userid, passwd);\n\t\t\tpstmt = con.prepareStatement(GET_ALL_STMT);\n\t\t\trs = pstmt.executeQuery();\n\n\t\t\twhile (rs.next()) {\n\t\t\t\t// empVO 也稱為 Domain objects\n\t\t\t\tnewsVO = new NewsVO();\n\t\t\t\tnewsVO.setNews_id(rs.getString(\"news_id\"));\n\t\t\t\tnewsVO.setNews_content(rs.getString(\"news_content\"));\n\t\t\t\tnewsVO.setNews_date(rs.getTimestamp(\"news_date\"));\n\t\t\t\tlist.add(newsVO); // Store the row in the list\n\t\t\t}\n\n\t\t\t// Handle any driver errors\n\t\t} catch (ClassNotFoundException e) {\n\t\t\tthrow new RuntimeException(\"Couldn't load database driver. \"\n\t\t\t\t\t+ e.getMessage());\n\t\t\t// Handle any SQL errors\n\t\t} catch (SQLException se) {\n\t\t\tthrow new RuntimeException(\"A database error occured. \"\n\t\t\t\t\t+ se.getMessage());\n\t\t\t// Clean up JDBC resources\n\t\t} finally {\n\t\t\tif (rs != null) {\n\t\t\t\ttry {\n\t\t\t\t\trs.close();\n\t\t\t\t} catch (SQLException se) {\n\t\t\t\t\tse.printStackTrace(System.err);\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (pstmt != null) {\n\t\t\t\ttry {\n\t\t\t\t\tpstmt.close();\n\t\t\t\t} catch (SQLException se) {\n\t\t\t\t\tse.printStackTrace(System.err);\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (con != null) {\n\t\t\t\ttry {\n\t\t\t\t\tcon.close();\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\te.printStackTrace(System.err);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\treturn list;\n\t}", "List<Videoinfo> selectAll();", "@SqlQuery(\"select * from PLAYERSTATS\")\n List<PlayerStats> getAll();", "public void ConsultaVehiculosSQlite() {\n preguntas = mydb.getCartList();\n for( int i = 0 ; i < preguntas.size() ; i++ ){\n //Toast.makeText(getApplicationContext(), preguntas.get( i ).getPregunta(), Toast.LENGTH_SHORT).show();\n persons.add(new Solicitud(\"Pregunta \" + String.valueOf(i+1) +\": \"+preguntas.get( i ).getPregunta(),\"Fecha: \"+ preguntas.get( i ).getFecha(), R.drawable.solicitudes,\"Motivo: \"+preguntas.get( i ).getMotivo(),\"Observacion: \"+preguntas.get( i ).getObservacion(),\"\"));\n }\n }", "List<PayLogInfoPo> selectByExample(PayLogInfoPoExample example);", "public void getProvinceList() {\n Log.i(TAG, \"getProvinceList\");\n this.mCityShowMode = false;\n if (this.mCityCursor != null) {\n this.mCityCursor.close();\n this.mCityCursor = null;\n }\n if (this.mCityRedMan != null) {\n this.mCityCursor = this.mCityRedMan.queryProvinceRec();\n if (this.mCityCursor != null) {\n Log.i(TAG, \"mCityCursor count = \" + this.mCityCursor.getCount());\n } else {\n Log.i(TAG, \"mCityCursor count = null\");\n }\n }\n }", "public List<Pai> getPaises() {\n\t\tList<Pai> retorno = new ArrayList<Pai>();\n\n\t\tQuery query = getEntityManager().createNamedQuery(\"Pai.findAll\");\n\t\tretorno = (List<Pai>) query.getResultList();\n\n\t\treturn retorno;\n\n\t}", "private List<Produto> retornaProduto (Long cod){\n \n Query q = entityManager.createNamedQuery(\"Produto.findByCodigo\");\n q.setParameter(\"codigo\", cod);\n List <Produto> p = q.getResultList();\n return p; \n}", "@ApiOperation(value = \"/get_all_UserNoun\", httpMethod = \"GET\",\n\tnotes = \"special search that gets all values of UserNoun\",\n\tresponse = UserNoun.class)\n @ApiResponses(value = {\n\t\t@ApiResponse(code = 200, message =LoginACTSwaggerUIConstants.SUCCESS),\n\t @ApiResponse(code = 404, message = LoginACTSwaggerUIConstants.NOT_FOUND),\n\t @ApiResponse(code = 500, message = LoginACTSwaggerUIConstants.INTERNAL_SERVER_ERROR),\n\t @ApiResponse(code = 400, message = LoginACTSwaggerUIConstants.BAD_REQUEST),\n\t @ApiResponse(code = 412, message = LoginACTSwaggerUIConstants.PRE_CONDITION_FAILED) })\n\n\n\t@RequestMapping(method = RequestMethod.GET,value = \"/get_all_UserNoun\" ,headers=\"Accept=application/json\")\n @ResponseBody\n\tpublic List<UserNoun> get_all_UserNoun() throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"get_all_UserNoun controller started operation!\");\n\n\t\tList<UserNoun> UserNoun_list = new ArrayList<UserNoun>();\n\n\t\tUserNoun_list = UserNoun_service.get_all_usernoun();\n\t\tlog.info(\"Object returned from get_all_UserNoun method !\");\n\t\treturn UserNoun_list;\n\n\n\t}", "List<SurveystatusPkey> selectByExample(SurveystatusPkeyExample example);", "@Test\n\tpublic void getAllByRegion() {\n\t\tList<String> consequenceTypeList = new ArrayList<String>();\n\t\tconsequenceTypeList.add(\"2KB_upstream_variant\");\n\t\tconsequenceTypeList.add(\"splice_region_variant\");\n\t\tList<Snp> snps = snpDBAdaptor.getAllByRegion(new Region(\"1\", 10327, 12807), consequenceTypeList);\n\t\tthis.printSNPList(\"getAllByRegion\", snps, 50);\n\t}", "public List<Dept> list() {\n try {\n List<Dept> dept = new ArrayList<Dept>();\n PreparedStatement stmt = this.connection\n .prepareStatement(\"select * from dept_sr\"); //here\n\n ResultSet rs = stmt.executeQuery();\n\n while (rs.next()) {\n // adiciona a tarefa na lista\n dept.add(populateDept(rs));\n }\n\n rs.close();\n stmt.close();\n\n return dept;\n } catch (SQLException e) {\n throw new RuntimeException(e);\n }\n }" ]
[ "0.66631794", "0.61398154", "0.60438216", "0.5644529", "0.5552517", "0.55466866", "0.5440571", "0.5398454", "0.5396645", "0.5378684", "0.53518856", "0.5305352", "0.52078885", "0.519873", "0.5177522", "0.5171791", "0.5153366", "0.5133475", "0.5109291", "0.5088844", "0.5082477", "0.5081626", "0.5066583", "0.5060632", "0.5060204", "0.50598645", "0.50576836", "0.5053652", "0.5046867", "0.5045723", "0.50309473", "0.50295824", "0.50241446", "0.5020068", "0.501856", "0.4998485", "0.49961182", "0.49763387", "0.49747238", "0.4968372", "0.49590668", "0.49542993", "0.49489695", "0.49395275", "0.49374902", "0.49291047", "0.49276456", "0.4926046", "0.49232942", "0.49222028", "0.49206576", "0.49158075", "0.4914407", "0.49129847", "0.49096805", "0.49036744", "0.48961255", "0.48871836", "0.4885572", "0.48831546", "0.48829287", "0.4882385", "0.48812297", "0.4874625", "0.4873208", "0.48688993", "0.4864926", "0.48568985", "0.48558402", "0.48558104", "0.4854753", "0.48535985", "0.48518875", "0.48516166", "0.48512903", "0.48506388", "0.48490784", "0.48449108", "0.48392072", "0.4838185", "0.48369896", "0.4826367", "0.48251316", "0.48228368", "0.4820556", "0.48191568", "0.4817497", "0.4814554", "0.48145485", "0.4814405", "0.48134795", "0.48124158", "0.4812412", "0.4809451", "0.48057577", "0.4803689", "0.48035312", "0.48010093", "0.47951263", "0.47929692" ]
0.65176284
1
auths not ready at this time The purpose of Dao method is to search a value in IPATestStage table from database based on given inputs
public ArrayList<IPATestStage> search_ipateststage(String name) throws Exception { log.setLevel(Level.INFO); log.info("search_ipateststage Dao started operation!"); try{ Query result = entityManager. createNativeQuery(search_IPATestStage,IPATestStage.class) .setParameter("name", name.concat("%")) ; ArrayList<IPATestStage> IPATestStage_list = (ArrayList<IPATestStage>)result.getResultList(); if(IPATestStage_list == null){ log.error("search_ipateststage Dao throws exception :" + "null" ); throw new Exception("null"); } log.info("Object returned from search_ipateststage Dao method !"); return (ArrayList<IPATestStage>) IPATestStage_list; }catch(Exception e){ //new Exception(e.toString()); // this needs to be changed log.error("search_ipateststage Dao throws exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public IPATestStage ipateststage_search_for_update(long id, IPUser user) throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"ipateststage_search_for_update Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(search_for_update_IPATestStage,IPATestStage.class)\n\n\t\t\t.setParameter(\"id\", id);;\n\n\t\t\tArrayList<IPATestStage> IPATestStage_list =\t(ArrayList<IPATestStage>)result.getResultList();\n\n\t\t\tif(IPATestStage_list == null){\n\n\t\t\tlog.error(\"ipateststage_search_for_update Dao throws exception :\" + \"no IPATestStage found\" );\n\t\t\tthrow new Exception(\"no IPATestStage found\");\n\t\t\t}\n\t\t\tlog.info(\"Object returned from ipateststage_search_for_update Dao method !\");\n\t\t\treturn (IPATestStage) IPATestStage_list.get(0);\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"ipateststage_search_for_update Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public void testFindByField() throws SQLException, ClassNotFoundException {\r\n\t\t// create an instance to be test\r\n\t\tDate d = Date.valueOf(\"2017-01-01\");\r\n\t\tService ser = new Service(\"employee\", 1, \"variation\", \"note\", d, d, 1, 1);\r\n\t\tmodelDS.insert(ser); \r\n\r\n\t\t// method to test\r\n\t\tLinkedList<Service> listActivity = modelDS.findByField(\"employee\", \"employee\");\r\n\r\n\t\t// database extrapolation\r\n\t\tPreparedStatement ps = connection.prepareStatement(\"SELECT * FROM \" + TABLE_NAME + \" WHERE employee LIKE ?\");\r\n\t\tps.setString(1, \"employee\"+\"%\");\r\n\t\tResultSet rs = ps.executeQuery();\r\n\t\tService expected = null;\r\n\t\tint index = 0;\r\n\t\twhile (rs.next()) {\r\n\t\t\texpected = new Service();\r\n\t\t\texpected.setId(rs.getInt(\"id\"));\r\n\t\t\texpected.setEmployee(rs.getString(\"employee\"));\r\n\t\t\texpected.setQuantity(rs.getInt(\"quantity\"));\r\n\t\t\texpected.setVariation(rs.getString(\"variation\"));\r\n\t\t\texpected.setNote(rs.getString(\"note\"));\r\n\t\t\texpected.setReceiptDate(rs.getDate(\"receipt_date\"));\r\n\t\t\texpected.setReturnDate(rs.getDate(\"return_date\"));\r\n\t\t\texpected.setArticleId(rs.getInt(\"article_id\"));\r\n\t\t\texpected.setCustomerId(rs.getInt(\"customer_id\"));\r\n\t\t\tassertEquals(true, listActivity.get(index).equals(expected));\r\n\t\t\tindex++;\r\n\t\t}\r\n\r\n\t\tmodelDS.remove(expected.getId()); // return to the initial state of the\r\n\t\t\t\t\t\t\t\t\t\t\t// database before test\r\n\t}", "public ArrayList<IPATestStage> get_all_ipateststage() throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"get_all_ipateststage Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(get_all_IPATestStage,IPATestStage.class)\n\n;\n\n\t\t\tArrayList<IPATestStage> IPATestStage_list =\t(ArrayList<IPATestStage>)result.getResultList();\n\n\t\t\tif(IPATestStage_list .size() < 1){\n\n\t\t\tlog.error(\"get_all_ipateststage Dao throws exception :\" + \"no IPATestStage found\" );\n\t\t\tthrow new Exception(\"no IPATestStage found\");\n\t\t\t}\n\t\t\tlog.info(\"Object returned from get_all_ipateststage Dao method !\");\n\t\t\treturn (ArrayList<IPATestStage>) IPATestStage_list;\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"get_all_ipateststage Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public Cursor getassessmentcmp(String stageid)\n {\n \ttry\n \t{\n \t\tString sql=\"SELECT * FROM assessment where stageId='\"+stageid+\"' and result='true'\";\n \t\t\n \t\tCursor mCur=mDb.rawQuery(sql, null);\n \t\tif(mCur!=null)\n \t\t{\n \t\t\tmCur.moveToNext();\n \t\t}\n \t\treturn mCur;\n \t}\n \tcatch(SQLException mSQLException)\n \t{\n \t\tLog.e(TAG, \"getTestData >>\"+ mSQLException.toString());\n \t\tthrow mSQLException;\n \t}\n }", "public interface PlanDao extends JpaRepository<Plan,Long> {\n Plan findByPrepodAndStartYear(Prepod prepod, int startYear);\n}", "static void searchProductDB() {\n\n int productID = Validate.readInt(ASK_PRODUCTID); // store product ID of user entry\n\n\n productDB.findProduct(productID); // use user entry as parameter for the findProduct method and if found will print details of product\n\n }", "public static void search() {\n int userSelected = selectFromList(crudParamOptions);\n switch (userSelected){\n case 1:\n searchFirstName();\n break;\n case 2:\n searchLastName();\n break;\n case 3:\n searchPhone();\n break;\n case 4:\n searchEmail();\n break;\n default:\n break;\n }\n }", "private String stageDetailsFromDB(String queryString){\n\t\tString RET=\"\";\n\t\ttry\n\t\t{\n\t\t\tcon = Globals.getDatasource().getConnection();\n\t\t\tps = con.prepareStatement(queryString); \n\t\t\tresult = ps.executeQuery();\n\t\t\tif (result.first()) {\n\t\t\t\tRET = result.getString(1);\n\t\t\t}\n\t\t\t\n\t\t\t\n\t\t}\n\t\tcatch(SQLException sqle){sqle.printStackTrace();}\n\t\tfinally {\n\t\t Globals.closeQuietly(con, ps, result);\n\t\t}\n\t\treturn RET;\n\t}", "@Transactional\n\tpublic IPATestStage update_ipateststage(IPATestStage IPATestStage, IPUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"update_ipateststage Dao started operation!\");\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(update_IPATestStage)\n\t\t\t.setParameter(\"id\", IPATestStage.getId())\n\t\t\t.setParameter(\"name\", IPATestStage.getName())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from update_ipateststage Dao method !\");\n\n\t\t\treturn IPATestStage;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (update_ipateststage) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public interface PlanDao extends JpaRepository<Plan, Integer> {\n List<Plan> findByQrPass(String pass);\n}", "@FXML\r\n private void search(){\n \r\n String s = tfSearch.getText().trim(); \r\n String type = cmbType.getSelectionModel().getSelectedItem();\r\n String col = cmbFilterBy.getSelectionModel().getSelectedItem();\r\n \r\n /**\r\n * Column Filters\r\n * \r\n */\r\n \r\n \r\n if(!s.isEmpty()){\r\n if(!chbtoggleInActiveTraining.isSelected()){\r\n db.populateTable(trainingFields+ \" WHERE title LIKE '%\"+s+\"%' AND status<>'active'\", tblTrainingList);\r\n }\r\n\r\n if(chbtoggleInActiveTraining.isSelected()){\r\n db.populateTable(trainingFields+ \" WHERE title LIKE '%\"+s+\"%'\", tblTrainingList);\r\n } \r\n } \r\n }", "@Test\n public void testFindByLogin() throws Exception {\n String userName = String.valueOf(databaseTester.getConnection().createDataSet().getTable(\"User\")\n .getValue(0, \"login\"));\n// User user = jdbcUserDao.findByLogin(userName);\n// assertNotNull(\"Should find user by login\", user);\n }", "public Cursor getallsessment(String stageid)\n {\n \ttry\n \t{\n \t\tString sql=\"SELECT * FROM assessment where stageId='\"+stageid+\"'\";\n \t\t\n \t\tCursor mCur=mDb.rawQuery(sql, null);\n \t\tif(mCur!=null)\n \t\t{\n \t\t\tmCur.moveToNext();\n \t\t}\n \t\treturn mCur;\n \t}\n \tcatch(SQLException mSQLException)\n \t{\n \t\tLog.e(TAG, \"getTestData >>\"+ mSQLException.toString());\n \t\tthrow mSQLException;\n \t}\n }", "private static void search_by_id() {\r\n\t\ttry (// Creates a connection and statement object\r\n\t\t\t\tConnection conn = DriverManager.getConnection(\"jdbc:mysql://localhost:3306/PoisedPMS\",\"poisedpms\",\"poisedpms\");\r\n\t\t\t\t\r\n\t\t\t\tStatement stmt = conn.createStatement();\r\n\t\t\t\t\r\n\t\t\t){\r\n\t\t\tScanner input = new Scanner(System.in);\r\n\t\t\r\n\t\t\tSystem.out.println(\"Project id: \");\r\n\t\t\tString project_id_str = input.nextLine();\r\n\t\t\r\n\t\t\tString strSelectProject = String.format(\"SELECT * FROM projects INNER JOIN project_statuses ON \"\r\n\t\t\t\t\t+ \"projects.project_id = project_statuses.project_id;\");\r\n\t\t\tResultSet project_rset = stmt.executeQuery(strSelectProject);\r\n\t\t\t\r\n\t\t\tfetch_all_project_info(stmt, project_id_str, project_rset);\r\n\t\t/**\r\n\t\t * @exception If entered project id cannot be found in the projects table then an SQLException is thrown\r\n\t\t */\t\r\n\t\t} catch ( SQLException ex ) {\r\n\t\t\tex . printStackTrace ();\r\n\t\t}\r\n\t\t\r\n\t}", "public interface IProvinceLoginByDayDao {\n /**\n * 根据省份后期多日登录数据\n * @param province\n * @param beginDate\n * @param endDate\n * @return\n */\n ArrayList<AreaLoginByDayPo> findByProvince(String province,int beginDate,int endDate);\n}", "@Override\n public boolean SearchSQL() {\n\n /*\n appunto su query.next()\n inizialmente query.next è posto prima della prima riga\n alla prima chiaata si posiziona sulla prima row\n alla seconda chiamata si posiziona sulla seconda row e cosi via\n */\n\n boolean controllo = false;\n\n openConnection();\n\n String sql =\"select user,pass,vol_o_cand from pass where user='\"+userInserito+\"'\";\n ResultSet query = selectQuery(sql);\n\n try {\n\n if(query.next()){\n\n String pass = query.getString(\"pass\");\n\n if(pass.equals(passInserita)) {\n controllo = true;\n volocand = query.getString(\"vol_o_cand\");\n }\n\n }\n\n\n }catch(SQLException se){\n se.printStackTrace();\n }finally{\n closeConnection();\n }\n\n\n return controllo;\n\n }", "@Test\n public void testFindBySsoId() {\n LOGGER.info(\"findBySsoId\");\n String ssoId = \"sam\";\n AppUser result = userRepo.findBySsoId(ssoId);\n assertNotNull(result);\n }", "Salaries selectByPrimaryKey(@Param(\"empNo\") Integer empNo, @Param(\"fromDate\") Date fromDate);", "ArrayList<E> getWhere(String parameterName, int parameterValue, E dummyObject) throws DatabaseNotAccessibleException, DatabaseObjectNotFoundException, NoSuchFieldException;", "@Query(value = \"Select * From Seat Where row_number = ?1 and col_number = ?2 and train_train_id = ?3 \",nativeQuery=true)\n public Optional<Seat> checkSeatAvailability(int r, int c, int trainId);", "List<SysTeam> selectByExample(SysTeamExample example);", "@Transactional\n\tpublic IPATestStage create_ipateststage(IPATestStage IPATestStage, IPUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"create_ipateststage Dao started operation!\");\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(create_IPATestStage)\n\t\t\t.setParameter(\"name\", IPATestStage.getName())\n\t\t\t.setParameter(\"created_by\", user == null ? 0:user.getId())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tint insertedId = query.executeUpdate();\n\t\t\t\t\tString lastIndex=\"select last_insert_id()\";\n\t\t\t\t\tQuery sql = entityManager.createNativeQuery(lastIndex);\n\t\t\t\t\tBigInteger new_id = (BigInteger) sql.getSingleResult();\n\t\t\t\t\tIPATestStage.setId(new_id.longValue());\n\t\t\t\t\tSystem.out.println(\"create data---\"+insertedId);\n\n\t\t\tlog.info(\"Object returned from create_ipateststage Dao method !\");\n\n\t\t\treturn IPATestStage;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (create_ipateststage) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public interface JpSkillLevelRepository extends JpaRepository<JpSkillLevel,Long> {\n\n @Query(\"SELECT jpSkillLevel from JpSkillLevel jpSkillLevel where lower(jpSkillLevel.name) = :name\")\n JpSkillLevel findOneByName(@Param(\"name\") String name);\n\n @Query(\"SELECT jpSkillLevel from JpSkillLevel jpSkillLevel where jpSkillLevel.status = :status\")\n Page<JpSkillLevel> findAllActive(Pageable pageable, @Param(\"status\") Boolean status);\n}", "@Test\n\tvoid existDataInDBTest() {\n\t\tparkName = \"Haifa Park\";\n\t\tdate = new Date(120, 2, 1);\n\t\texpected = \"1 2 3 4 5 6 1 23 2 8 9 2 3 2 4 3 2 2 1 1 1 5 32 6 12 7 23 8 12 5 32 6 12 5 23 7\";\n\t\tresult = ReportsController.getReport(date, reportType, parkName);\n\n\t\tassertEquals(expected, result);\n\n\t}", "@Test\n\tvoid existDataInDBTest2() {\n\t\tparkName = \"Tel-Aviv Park\";\n\t\tdate = new Date(120, 5, 1);\n\t\texpected = \"11 22 33 44 55 66 17 23 5 8 4 2 3 2 54 34 2 32 1 61 1 75 32 46 12 67 23 82 12 56 32 36 12 85 232 7\";\n\t\tresult = ReportsController.getReport(date, reportType, parkName);\n\n\t\tassertEquals(expected, result);\n\n\t}", "List<ResultsView1> findByCadd(String addrs);", "List<InspectionAgency> selectByExample(InspectionAgencyExample example);", "@Test\n public void testWhere_withValidQuery() {\n String column0 = \"user_id\";\n String column1 = \"age\";\n int idValue0 = 0;\n int ageValue0 = 23;\n int idValue1 = 1;\n int ageValue1 = 22;\n int idValue2 = 2;\n int ageValue2 = 18;\n\n try {\n String sql = \"CREATE TABLE ModelExtension (\" +\n column0 + \" int, \" +\n column1 + \" int)\";\n PreparedStatement pstmt = Setup.getConnection().prepareStatement(sql);\n pstmt.execute();\n sql = \"INSERT INTO ModelExtension (\" +\n column0 + \", \" +\n column1 + \") VALUES (\" +\n idValue0 + \", \" +\n ageValue0 + \"), (\" +\n idValue1 + \", \" +\n ageValue1 + \"), (\" +\n idValue2 + \", \" +\n ageValue2 + \")\";\n pstmt = Setup.getConnection().prepareStatement(sql);\n pstmt.executeUpdate();\n } catch (SQLException e) {\n e.printStackTrace();\n assertTrue(false);\n }\n\n List<ModelExtension> models = child.findAll().where(column1 + \">20\").execute(ModelExtension.class);\n\n assertEquals(2, models.size());\n assertEquals(idValue0, models.get(0).get(column0));\n assertEquals(ageValue0, models.get(0).get(column1));\n assertEquals(idValue1, models.get(1).get(column0));\n assertEquals(ageValue1, models.get(1).get(column1));\n }", "ArrayList<E> getWhere(String parameterName, String parameterValue, E dummyObject) throws DatabaseNotAccessibleException, DatabaseObjectNotFoundException, NoSuchFieldException;", "SdkMobileVcode selectByPrimaryKey(Integer vid);", "ec_environment selectByPrimaryKey(Integer id);", "public List<Active> findByUser_UserID(String userID);", "@Query(value = \"SELECT * FROM position_employee pe WHERE pe.position_employee_code = :positionEmployeeCode AND pe.company_id = :companyID\", nativeQuery = true)\n PositionEmployeeEntity findPositionEmployeeByPositionEmployeeCodeAndCompanyID(@Param(\"positionEmployeeCode\") String positionEmployeeCode, @Param(\"companyID\") int companyID);", "@Test\r\n public void testFindActivityRecordBySportActivity() {\r\n SportActivity activity = new SportActivity();\r\n activity.setName(\"Test activity\");\r\n activityDao.createSportActivity(activity);\r\n\r\n ActivityRecord rec1 = setActivityRecord();\r\n rec1.setActivity(activity);\r\n recordDao.create(rec1);\r\n assertNotNull(recordDao.findActivityRecord(rec1.getId()));\r\n\r\n ActivityRecord rec2 = setActivityRecord();\r\n rec2.setActivity(activity);\r\n recordDao.create(rec2);\r\n assertNotNull(recordDao.findActivityRecord(rec2.getId()));\r\n\r\n ActivityRecord rec3 = setActivityRecord();\r\n recordDao.create(rec3);\r\n assertNotNull(recordDao.findActivityRecord(rec3.getId()));\r\n\r\n List<ActivityRecord> records = recordDao.findRecordsBySportActivity(activity);\r\n assertTrue(!records.isEmpty());\r\n assertTrue(records.contains(rec1));\r\n assertTrue(records.contains(rec2));\r\n assertTrue(!records.contains(rec3));\r\n }", "@Repository\npublic interface AddressDao {\n @Select(\"<script>\" +\n \" select provinceid,province \" +\n \" from provinces \" +\n \" where 1=1 \" +\n \" <if test=\\\"provinceid != null and provinceid != '' \\\">\" +\n \" and provinceid= #{provinceid} \" +\n \" </if>\" +\n \" <if test=\\\"province != null and province != '' \\\">\" +\n \" and province= #{province} \" +\n \" </if>\" +\n \"</script>\")\n List<Map<String, Object>> province(Map<String, Object> params);\n\n @Select(\"<script>\" +\n \" select cityid,city \" +\n \" from cities \" +\n \" where 1=1 \" +\n \" <if test=\\\"cityid != null and cityid != '' \\\">\" +\n \" and cityid= #{cityid} \" +\n \" </if>\" +\n \" <if test=\\\"city != null and city != '' \\\">\" +\n \" and city= #{city} \" +\n \" </if>\" +\n \" <if test=\\\"provinceid != null and provinceid != '' \\\">\" +\n \" and provinceid= #{provinceid} \" +\n \" </if>\" +\n \"</script>\")\n List<Map<String, Object>> city(Map<String, Object> params);\n\n @Select(\"<script>\" +\n \" select areaid,area \" +\n \" from areas \" +\n \" where 1=1 \" +\n \" <if test=\\\"areaid != null and areaid != '' \\\">\" +\n \" and areaid= #{areaid} \" +\n \" </if>\" +\n \" <if test=\\\"area != null and area != '' \\\">\" +\n \" and area= #{area} \" +\n \" </if>\" +\n \" <if test=\\\"cityid != null and cityid != '' \\\">\" +\n \" and cityid= #{cityid} \" +\n \" </if>\" +\n \"</script>\")\n List<Map<String, Object>> area(Map<String, Object> params);\n\n @Select(\"<script>\" +\n \" select provinceid,province \" +\n \" from provinces \" +\n \" where province= #{province} \" +\n \"</script>\")\n String getProvinceid(String province);\n\n @Select(\"<script>\" +\n \" select cityid,city \" +\n \" from cities \" +\n \" where city= #{city} \" +\n \"</script>\")\n String getCityid(String city);\n\n @Select(\"<script>\" +\n \" select areaid,area \" +\n \" from areas \" +\n \" where area= #{area} \" +\n \"</script>\")\n String getAreaid(String area);\n}", "@Override\n public void verifyDB_SIB_BID_Reg_Referral_Status(List<String> status, String table) {\n\n String condition;\n if (table.equals(\"purchase\")) {\n table = \"purchase_referral\";\n condition = \"create_date > sysdate -.01\";\n }\n else if (table.equals(\"registration\")) {\n table = \"registration_referral\";\n condition = \"customer_id =\" + this.getCustomerIDFromDB(authenticationParameters.getUsername());\n }\n else { //search_referral\n table = \"search_referral\";\n condition = \"search_id =\" + this.getSearchIDFromDB(authenticationParameters.getUsername());\n }\n\n String sql = \"select distinct referral_type, referrer_id, link_id, \" +\n \"version_id, keyword_id, match_type_id \" +\n \" from \" + table + \" where referral_type='\" + status.get(0) + \"'\" +\n \" and \" + condition;\n\n System.out.println(sql);\n Map<String, Object> sqlRowSet = jdbcTemplate.queryForMap(sql);\n\n System.out.println(\"Expected params in DB\" + status.toString());\n System.out.println(\"Actual param in DB\" + sqlRowSet.values().toString());\n assertThat(status.toString())\n .as(\"Transaction data stored in db\")\n .contains(sqlRowSet.values().toString());\n\n //check create date\n sql = \"select create_date \" +\n \" from \" + table + \" where \" + condition +\n \" and referral_type='\" + status.get(0) + \"'\" +\n \" and rownum <= 1\";\n\n\n sqlRowSet = jdbcTemplate.queryForMap(sql);\n DateFormat formatterDate = new SimpleDateFormat(\"yyyy-MM-dd\");\n Date current_date = new Date();\n Date dateDB = (Date) sqlRowSet.get(\"CREATE_DATE\");\n assertThat(dateDB.toString())\n .as(\"Transaction data(CREATE_DATE) stored in db\")\n .contains(formatterDate.format(current_date));\n }", "public void test_findListBySqlMap() {\r\n\t\t// step 1:\r\n\t\tList personList = this.persistenceService.findListBySqlMap(FIND_PERSON_BY_SQLMAP, NAME_PARAM[0]);\r\n\t\tassertForFindGoingmm(personList);\r\n\t}", "public Employee findEmployee(IncomingReport incoming_report) throws IllegalArgumentException, DAOException;", "@Override\r\n\tpublic List<Object[]> plantAdvanceSearch(String plant) {\n\t\tString hql=null;\r\n\t\tif(plant.equalsIgnoreCase(\"ALL\"))\r\n\t\t{\r\n\t\t\thql=\"select p.plantId ,p.plantName,p.add1,p.add2,p.add3,p.city,p.state,p.phone,p.fax,p.mobile,p.organization,p.countrysList from Plant p\";\r\n\t \r\n\t\t}\r\n\t\t\r\n\t\tif(!plant.equalsIgnoreCase(\"ALL\"))\r\n\t\t{\t\r\n\t\thql=\"select p.plantId ,p.plantName,p.add1,p.add2,p.add3,p.city,p.state,p.phone,p.fax,p.mobile,p.organization,p.countrysList from Plant p where \"+plant;\r\n\t\t\r\n\t\t}\r\n\t\t\r\n\t List<Object[]> list=getHibernateTemplate().find(hql);\r\n\t\r\n\t\t\treturn list;\t\r\n\t}", "public interface ProductInfoRepository extends JpaRepository<ProductInfo,String>{\n\n List<ProductInfo> findByProductStatus(Integer status);\n\n}", "List<PmKeyDbObj> selectByExample(PmKeyDbObjExample example);", "@Select(\"select perf_submit_flag from fm_perf_submit_info where year =#{year} and month=#{month} and plat_id =#{platId}\")\n Boolean getPerfSubmitFlag(@Param(\"platId\") Long platId, @Param(\"year\") int year, @Param(\"month\") int month);", "PaasCustomAutomationRecord selectByPrimaryKey(Integer id);", "public Vector findAll(String login, Boolean isAdmin) throws Exception {\n \nDebugSupport.printlnTest(\"RegionObject findAll started\");\t\n\tQuery query;\n\n if (!isAdmin.booleanValue()) {\n query = new Query(QUERY_SELECT_View, DataUtil.RESULT_JdbcObjectVector);\n query.append(\"AND o.loiginid=?\", login);\n } else {\n query = new Query(QUERY_SELECT_Admin, DataUtil.RESULT_JdbcObjectVector);\n }\n\n query.append(\"ORDER BY regname\");\n\n Vector vec= findVector(query);\n return vec;\n}", "public void testFindByKey() throws SQLException, ClassNotFoundException {\r\n\t\t// create an instance to be test\r\n\t\tDate d = Date.valueOf(\"2017-01-01\");\r\n\t\tService ser = new Service(\"employee\", 1, \"variation\", \"note\", d, d, 1, 1);\r\n\t\tmodelDS.insert(ser); \r\n\t\tint id = -1;\r\n\t\tLinkedList<Service> list = modelDS.findAll();\r\n\t\tfor (Service a : list) {\r\n\t\t\tif (a.equals(ser))\r\n\t\t\t\tid = a.getId();\r\n\t\t}\r\n\r\n\t\t// method to test\r\n\t\tService service = modelDS.findByKey(id);\r\n\r\n\t\t// database extrapolation\r\n\t\tPreparedStatement ps = connection.prepareStatement(\"SELECT * FROM \" + TABLE_NAME + \" WHERE id = ?\");\r\n\t\tps.setInt(1, id);\r\n\t\tResultSet rs = ps.executeQuery();\r\n\t\tService expected = null;\r\n\t\twhile (rs.next()) {\r\n\t\t\texpected = new Service();\r\n\t\t\texpected.setId(rs.getInt(\"id\"));\r\n\t\t\texpected.setEmployee(rs.getString(\"employee\"));\r\n\t\t\texpected.setQuantity(rs.getInt(\"quantity\"));\r\n\t\t\texpected.setVariation(rs.getString(\"variation\"));\r\n\t\t\texpected.setNote(rs.getString(\"note\"));\r\n\t\t\texpected.setReceiptDate(rs.getDate(\"receipt_date\"));\r\n\t\t\texpected.setReturnDate(rs.getDate(\"return_date\"));\r\n\t\t\texpected.setArticleId(rs.getInt(\"article_id\"));\r\n\t\t\texpected.setCustomerId(rs.getInt(\"customer_id\"));\r\n\t\t}\r\n\r\n\t\t// compare database result with the method tested\r\n\t\tassertNotNull(expected);\r\n\t\tassertNotNull(service);\r\n\t\tassertEquals(expected, service);\r\n\r\n\t\tmodelDS.remove(expected.getId()); // return to the initial state of the\r\n\t\t\t\t\t\t\t\t\t\t\t// database before test\r\n\t}", "public interface EventRepository extends JpaRepository<Event, Long> {\r\n\t@Query(\" from Event where event_city=:city\")\r\n\tpublic List<Event> findByCity(@Param(\"city\") String city);\r\n}", "public boolean hasObject(SQLiteDatabase db,String TableName,\n String dbfield, String fieldValue) {\n String selectString = \"SELECT * FROM \" + TableName + \" WHERE \" + dbfield + \" =?\";\n\n // Add the String you are searching by here.\n // Put it in an array to avoid an unrecognized token error\n Cursor cursor = db.rawQuery(selectString, new String[] {fieldValue});\n\n boolean hasObject = false;\n if(cursor.moveToFirst()){\n hasObject = true;\n\n //region if you had multiple records to check for, use this region.\n\n int count = 0;\n while(cursor.moveToNext()){\n count++;\n }\n //here, count is records found\n Log.d(\"uzair\", String.format(\"%d records found\", count));\n\n //endregion\n\n }\n\n cursor.close(); // Dont forget to close your cursor\n db.close(); //AND your Database!\n return hasObject;\n }", "@Repository\npublic interface AppointmentRepo extends JpaRepository<AppointmentEntity,Integer>{\n\t@Query(\"select a from AppointmentEntity a where a.testId=:tid and a.dateTime=:dt\")\n\tpublic AppointmentEntity getAppointmentBytestIdAndDateTime(@Param(\"dt\") String dateTime, @Param(\"tid\") String testId);\n\t\n\t@Query(\"FROM AppointmentEntity where centreId =:cid\")\n\tpublic List<AppointmentEntity> findAll(@Param(\"cid\") String centreId);\n\t\n\t@Query(\"FROM AppointmentEntity where userId =:uid\")\n\tpublic List<AppointmentEntity> findAllByUserId(@Param(\"uid\") String userId);\n\t\n\t\n\n\n\n\t\n}", "List<Province> selectByExample(ProvinceExample example);", "public Cursor getallchecklistindex(String stageid)\n {\n \ttry\n \t{\n \t\tString sql=\"select checklist.Id,checklist.checknum,checklist.name,checklist.rpl from checklistindex inner join checklist on checklistindex.checknum=checklist.checknum where checklistindex.stageid='\"+stageid+\"' GROUP BY checklistindex.checknum\";\n \t\t\n \t\tCursor mCur=mDb.rawQuery(sql, null);\n \t\tif(mCur!=null)\n \t\t{\n \t\t\tmCur.moveToNext();\n \t\t}\n \t\treturn mCur;\n \t}\n \tcatch(SQLException mSQLException)\n \t{\n \t\tLog.e(TAG, \"getTestData >>\"+ mSQLException.toString());\n \t\tthrow mSQLException;\n \t}\n }", "public void action_call(ActionEvent actionEvent) {\n ViewObject searchVO=am.getPOCHeaderView1();\n ViewObject pocvo=am.getpocSearchVo1();\n String poc_id=null;\n int Buyer=0;\n int org=0;\n String orgname=null;\n try{\n poc_id=pocvo.getCurrentRow().getAttribute(\"PocId\").toString();\n }\n catch(Exception e) {\n poc_id=null;\n }\n \n int pram=1;\n am.getDBTransaction().commit();\n /***ViewObject oder=am.getOrderRecapSummary1();\n ViewObject oder=am.getorder_recap_new_view1();\n oder.setNamedWhereClauseParam(\"param\",pram);\n oder.setWhereClause(\"SEASON = '\"+season+\"' AND BUYER_ID = '\"+Buyer+\"' AND ORG_ID= '\"+org+\"'\");\n **/\n \n \n searchVO.setNamedWhereClauseParam(\"param\",pram);\n searchVO.setWhereClause(\"POC_ID = '\"+poc_id+\"'\");\n \n \n \n searchVO.executeQuery();\n \n \n AdfFacesContext.getCurrentInstance().addPartialTarget(pocTable); \n \n \n \n \n \n }", "@Test\n\tpublic void searchForPendingLiveByUnitNbr_FuncTest(){\n\t\tpendingLiveUnit = (String)em.createNativeQuery(TestQueryConstants.READ_PENDING_LIVE_UNIT_NO).getSingleResult().toString();\n\t\tList<DriverSearchVO> drivers = driverService.searchDriver(null, null, null, null, pendingLiveUnit, null, null, null, true,null, null, null);\t\n\t\tlong driversCnt = driverService.searchDriverCount(null, null, null, null, pendingLiveUnit, null, null, null, true,null);\n\t\t// we get back one result\n\t\tassertEquals(1, driversCnt);\n\t\t\n\t\tif(drivers.get(0).getContractLineStartDate() != null){\n\t\t\t// that result has a start date in the future\n\t\t\tassertTrue(drivers.get(0).getContractLineStartDate().after(new Date(System.currentTimeMillis())));\n\t\t}\n\t}", "public interface TimeScaleApplicationRepository extends JpaRepository<TimeScaleApplication,Long> {\n\n @Query(\"select timeScaleApplication from TimeScaleApplication timeScaleApplication where timeScaleApplication.instEmployee.code = :code\")\n TimeScaleApplication findByInstEmployeeCode(@org.springframework.data.repository.query.Param(\"code\") String code);\n}", "public void search() throws SQLException;", "@Override\r\npublic int selectByPrimaryKey(Integer possalesdetailid) {\n\t\r\n\tPossalesdetail p= possalesdetail.selectByPrimaryKey(possalesdetailid);\r\n if(p.getPossalesdetailid()>0){\r\n \t\r\n \treturn 1;\r\n } else{\r\n\t return 0;\r\n }\r\n}", "public Vector findEditBySuperRegion(\n Integer supregid,\n String login,\n Boolean isAdmin,\n String planstate)\n throws Exception {\n Query query = null;\n\n if (!isAdmin.booleanValue()) {\n\n if (planstate.equals(Checks.POSITION_PLANSTATE_Fact)) {\n query = new Query(QUERY_SELECT_EditFact, RESULT_JdbcObjectVector);\n\n } else\n if (planstate.equals(Checks.POSITION_PLANSTATE_Plan)) {\n query = new Query(QUERY_SELECT_EditPlan, RESULT_JdbcObjectVector);\n }else{\n\t query = new Query(QUERY_SELECT_Edit, RESULT_JdbcObjectVector);\n\t }\n query.append(\"AND o.loiginid=?\", login);\n } else {\n query = new Query(QUERY_SELECT_Admin, DataUtil.RESULT_JdbcObjectVector);\n }\n query.append(\"AND r.supregid=?\", supregid);\n query.append(\"ORDER BY regname\");\n\n return findVector(query);\n}", "public GradeBean findBySeq(int input4);", "List<Engine> selectByExample(EngineExample example);", "ProEmployee selectByPrimaryKey(String id);", "FunctionInfo selectByPrimaryKey(String fucno);", "@Repository\r\npublic interface FixtureRepo extends CrudRepository<Fixture,Integer> {\r\n List<Fixture> findByTournamentID(int id);\r\n Fixture findByMatchNo(int id);\r\n}", "public interface AppHealthDataDao {\n public AppHealthData findByType(String type, String idNo) throws Exception;\n\n public AppHealthData findByPatientId(String patientId, String ghh000,String type) throws Exception;\n\n public void addHealthDataImplements(JSONObject jsonall,String idNo,String card,String type,String requestUserId,String requestUserName,String userType) throws Exception;\n}", "List<Student> findAllByStatus(Student.Status status);", "@Repository\npublic interface DeviceTypeDao extends CrudRepository<DeviceType,Long> {\n\n DeviceType findByChinatypename(String chinatypename);\n\n// @Query(value=\"select * from tb_devicetype where chinatypename like ?1 or hextypename like ?1 or typename like ?1 or typenum like ?1\",nativeQuery=true)\n// DeviceType findSearch(String info);\n\n}", "@Test\n public void test() {\n\n /*\n * Testing to find all list of Offices\n */\n List<Employee> all = employeeDao.findAll();\n Assert.assertNotNull(all);\n for (Employee eml : all) {\n System.out.println(eml.toString());\n }\n Assert.assertEquals(5, all.size());\n\n /*\n * Testing to find Employee by ID\n */\n Employee employeeById = employeeDao.findById(3);\n Assert.assertNotNull(employeeById);\n Assert.assertEquals(\"Борис\", employeeById.getFirstName());\n Assert.assertEquals(3, employeeById.getOffice().getId().longValue());\n\n /*\n * Testing to find Employee by Filter without REQUIRED PARAMETER: OFFICE_ID\n */\n EmployeeFilter filterWithoutRequiredOfficeId = new EmployeeFilter();\n filterWithoutRequiredOfficeId.firstName = \"и\";\n List<Employee> employeeListWithoutRequiredOfficeId = employeeDao.findByFilter(filterWithoutRequiredOfficeId);\n Assert.assertNull(employeeListWithoutRequiredOfficeId);\n\n /*\n * Testing to find Employee by Filter with REQUIRED PARAMETER: OFFICE_ID + potential parameter firstNAme and citizenshipCode\n */\n EmployeeFilter filter = new EmployeeFilter();\n filter.officeId = 3;\n filter.firstName = \"рис\";\n List<Employee> employeeByFilterList = employeeDao.findByFilter(filter);\n Assert.assertNotNull(employeeByFilterList);\n for (Employee emp : employeeByFilterList) {\n System.out.println(emp.toString());\n }\n Assert.assertEquals(3, employeeByFilterList.get(0).getId().longValue());\n\n EmployeeFilter filter1 = new EmployeeFilter();\n filter1.officeId = 1;\n filter1.citizenshipCode = \"601\";\n List<Employee> employeeList = employeeDao.findByFilter(filter1);\n Assert.assertNotNull(employeeList);\n for (Employee emp : employeeList) {\n System.out.println(emp.toString());\n }\n Assert.assertEquals(1, employeeList.size());\n Assert.assertEquals(\"Российская Федерация\", employeeList.get(0).getCountry().getName());\n Assert.assertEquals(\"Никита\", employeeList.get(0).getFirstName());\n\n /*\n * Testing to save(add) new Employee\n */\n Office setableOffice = officeDao.findById(1);\n Document setableDocument = documentDao.findByCode(String.valueOf(21));\n Country setableCountry = countryDao.findByCode(String.valueOf(601));\n Assert.assertNotNull(setableOffice);\n Employee savableEmployee = new Employee();\n savableEmployee.setOffice(setableOffice);\n savableEmployee.setFirstName(\"Евгений\");\n savableEmployee.setPosition(\"программист\");\n savableEmployee.setDocument(setableDocument);\n savableEmployee.setCountry(setableCountry);\n employeeDao.save(savableEmployee);\n Employee empl2 = employeeDao.findById(6);\n System.out.println(empl2.toString());\n Assert.assertEquals(\"Евгений\", empl2.getFirstName());\n\n /*\n * Testing to update Employee by ID\n */\n Employee updatebleEmployee = employeeDao.findById(6);\n updatebleEmployee.setFirstName(\"Евгения\");\n updatebleEmployee.setSecondName(\"Лоськова\");\n updatebleEmployee.setPosition(\"младший программист\");\n updatebleEmployee.setIsIdentified(true);\n employeeDao.update(updatebleEmployee);\n System.out.println(employeeDao.findById(6).toString());\n Assert.assertEquals(\"Лоськова\", employeeDao.findById(6).getSecondName());\n }", "@Repository\npublic interface AnalyseResultRepository extends JpaRepository<AnalyseCsv,Integer> {\n/* Iterable<AnalyseCsv> findById(Integer resultid);*/\n\n/* //按名称进行模糊搜索\n List<DatamodelSource> findByfilenameLike(String sourcename);*/\n\n\n\n\n}", "@Override\n\t\t\tpublic TestEntity findById(BigInteger testId)\n\t\t\t{\n\t\t\t\t Optional<TestEntity>optional=testDao.findById(testId);\n\t\t\t if(optional.isPresent())\n\t\t\t {\n\t\t\t TestEntity test=optional.get();\n\t\t\t return test;\n\t\t\t }\n\t\t\t throw new TestNotFoundException(\"Test not found for id=\"+testId);\n\t\t\t }", "public LearningResultHasActivity[] findByDynamicWhere(String sql, Object[] sqlParams) throws LearningResultHasActivityDaoException;", "List<ec_environment> selectByExample(ec_environmentExample example);", "public Cliente[] findWhereEstadoEquals(String estado) throws ClienteDaoException;", "@Test\n public void test4FindPk() {\n SpecialityFactory factory = new MysqlSpecialityDAOFactry();\n SpecialityDAO dao = factory.create();\n SpecialityDTO respuesta = dao.findPk(\"telecomunicaciones\");\n assertEquals(respuesta,spec2);\n }", "public ResultSet appcomp(Long comp_id)throws SQLException {\n\trs=DbConnect.getStatement().executeQuery(\"select * from company where comp_id=\"+comp_id+\"\");\r\n\treturn rs;\r\n}", "@Test\n public void testShowSearchedApartment() throws SQLException {\n System.out.println(\"showSearchedApartment\");\n String location = \"gokarna\";\n ApartmentBLL instance = new ApartmentBLL();\n ResultSet result = instance.showSearchedApartment(location);\n assertTrue(result.next());\n }", "List<Card> search(String searchString, long userId) throws PersistenceCoreException;", "private Page<ElasticCandidate> search(CandidateSearchModel model, Pageable pageable){\n Integer experienceDuration = model.getSkillPlaceholder()\n .getExperienceDuration();\n String title = model.getSkillPlaceholder()\n .getSkill()\n .getTitle();\n RangeModel<Integer> rangeExperience = model.getSkillExperienceRange();\n Integer experienceUpperLimit = rangeExperience.getUpperLimit();\n Integer experienceLowerLimit = rangeExperience.getLowerLimit();\n\n // Prepares location\n String location = model.getLocation();\n\n // Prepare hourly rate\n Integer hourlyRate = model.getHourlyRate();\n RangeModel<Integer> rangeHourlyRate = model.getHourlyRateRange();\n Integer hourlyRateUpperLimit = rangeHourlyRate.getUpperLimit();\n Integer hourlyRateLowerLimit = rangeHourlyRate.getLowerLimit();\n\n // Prepares certifications\n Set<String> certifications = model.getCertifications();\n if (certifications != null && certifications.size() != 0) {\n Iterator iterator = certifications.iterator();\n String[] certificationsArray = new String[certifications.size()];\n for (int i = 0; i < certificationsArray.length; i++) {\n certificationsArray[i] = (String) iterator.next();\n }\n }\n\n // Prepares Starting date postponed !!\n// Long startingDate = model.getStartingDate().getTime();\n// Long startingDateUpperLimit = model.getStartingDateUpperRange().getTime();\n\n // Prepares time period\n String timePeriod = model.getTimePeriod();\n // endregion\n\n // region Build query\n SearchQuery searchQuery;\n\n\n if (certifications != null && certifications.size() != 0)\n searchQuery = new NativeSearchQueryBuilder().withQuery(matchAllQuery())\n\n\n .withQuery(\n boolQuery()\n .must(queryForMustSkill(title))\n .should(queryForExactValueSkill(title, experienceDuration))\n .should(queryForExactValueHourlyRate(hourlyRate))\n .should(queryForFuzzyHourlyRate(hourlyRate))\n .should(queryForFuzzySkill(title, experienceDuration))\n .should(queryForRangeSkill(title, experienceLowerLimit, experienceUpperLimit))\n .should(queryForRangeHourlyRate(hourlyRateLowerLimit, hourlyRateUpperLimit))\n .must(queryForLocation(location))\n// .must(queryForStartingDay(startingDate, startingDateUpperLimit))\n .must(queryForTimePeriod(timePeriod))\n .must(queryForCertifications(certifications)))\n .withPageable(pageable)\n .withFilter(queryForMustSkill(title))\n .withFilter(queryForExactValueSkill(title, experienceDuration))\n .withFilter(queryForExactValueHourlyRate(hourlyRate))\n .withFilter(queryForFuzzyHourlyRate(hourlyRate))\n .withFilter(queryForFuzzySkill(title, experienceDuration))\n .withFilter(queryForRangeSkill(title, experienceLowerLimit, experienceUpperLimit))\n .withFilter(queryForRangeHourlyRate(hourlyRateLowerLimit, hourlyRateUpperLimit))\n .withFilter(queryForLocation(location))\n .withFilter(queryForTimePeriod(timePeriod))\n .withFilter(queryForCertifications(certifications))\n// .withSort(SortBuilders.fieldSort(\"hourlyRate\")\n// .order(SortOrder.ASC))\n .build();\n\n else\n\n\n searchQuery = new NativeSearchQueryBuilder().withQuery(matchAllQuery())\n\n\n .withQuery(\n boolQuery()\n .must(queryForMustSkill(title))\n .should(queryForExactValueSkill(title, experienceDuration))\n .should(queryForExactValueHourlyRate(hourlyRate))\n .should(queryForFuzzyHourlyRate(hourlyRate))\n .should(queryForFuzzySkill(title, experienceDuration))\n .should(queryForRangeSkill(title, experienceLowerLimit, experienceUpperLimit))\n .should(queryForRangeHourlyRate(hourlyRateLowerLimit, hourlyRateUpperLimit))\n .must(queryForLocation(location))\n// .must(queryForStartingDay(startingDate, startingDateUpperLimit))\n .must(queryForTimePeriod(timePeriod)))\n .withPageable(pageable)\n .withFilter(queryForMustSkill(title))\n .withFilter(queryForExactValueSkill(title, experienceDuration))\n .withFilter(queryForExactValueHourlyRate(hourlyRate))\n .withFilter(queryForFuzzyHourlyRate(hourlyRate))\n .withFilter(queryForFuzzySkill(title, experienceDuration))\n .withFilter(queryForRangeSkill(title, experienceLowerLimit, experienceUpperLimit))\n .withFilter(queryForRangeHourlyRate(hourlyRateLowerLimit, hourlyRateUpperLimit))\n .withFilter(queryForLocation(location))\n .withFilter(queryForTimePeriod(timePeriod))\n// .withSort(SortBuilders.fieldSort(\"hourlyRate\")\n// .order(SortOrder.ASC))\n .build();\n\n // endregion\n\n // region Test\n Page<ElasticCandidate> queryForExactValueSkill = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForExactValueSkill(title, experienceDuration))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForExactValueHourlyRate = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForExactValueHourlyRate(hourlyRate))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForFuzzySkill = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForFuzzySkill(title, experienceDuration))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForFuzzyHourlyRate = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForFuzzyHourlyRate(hourlyRate))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForRangeSkill = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForRangeSkill(title, experienceLowerLimit, experienceUpperLimit))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForRangeHourlyRate = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForRangeHourlyRate(hourlyRateLowerLimit, hourlyRateUpperLimit))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForLocation = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForLocation(location))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForTimePeriod = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForTimePeriod(timePeriod))\n .build(), ElasticCandidate.class);\n Page<ElasticCandidate> queryForCertifications = elasticsearchTemplate.queryForPage(new NativeSearchQueryBuilder().withQuery(\n queryForCertifications(certifications))\n .build(), ElasticCandidate.class);\n // endregion\n\n\n Page<ElasticCandidate> sampleEntities = elasticsearchTemplate.queryForPage(searchQuery,\n ElasticCandidate.class);\n return sampleEntities;\n }", "public interface VoucherCodeRepository extends BaseRepository<VoucherCode,Long> {\n\n public VoucherCode findByVocId(Long vocId);\n\n public VoucherCode findByVocMerchantNoAndVocVoucherSourceAndVocIndex(Long vocMerchantNo,Long vocVoucherSource,Long vocIndex );\n\n}", "Integer find(Object[] o){\n\t try {\n\t\t\n\t ResultSet rs = SQLBot.bot.query(\"SELECT ID FROM Contracts WHERE Start_Date='\"+o[sd]+\n\t\t\t\t\t \"' AND abs(\"+sqlCol+\"-\"+o[tc]+\") <= 0.001\");\n\t //System.out.println(\"SELECT Customer_ID FROM Contracts WHERE Start_Date='\"+o[sd]+\n\t //\t\t \"' AND abs(\"+sqlCol+\"-\"+o[tc]+\") <= 0.001\");\n\t //check if it matches name\n\t ArrayList<Integer> acc = new ArrayList<Integer>();\n\t while(rs.next()){\n\t\tacc.add(rs.getInt(1));}\n\n\t for (int val: acc) if (nameMatch(val, (String)o[fn], (String)o[ln])) return val;\n\n\t } catch (Exception e){e.printStackTrace();}\n\t return null;\n\t}", "@SuppressWarnings(\"unused\")\n@Repository\npublic interface ModuleGradeRepository extends JpaRepository<ModuleGrade, Long> {\n\n List<ModuleGrade> findAllByIsAffectQca(@Param(\"is_affect_qca\") Boolean isAffectQca);\n}", "public LearningResultHasActivity[] findByDynamicSelect(String sql, Object[] sqlParams) throws LearningResultHasActivityDaoException;", "public Container<PosPay> findPosPay(PosPay posPay,int firstResult ,int maxResults)throws DataAccessException;", "Miss_control_log selectByPrimaryKey(String loginuuid);", "private static void search_by_name() {\r\n\t\ttry (// Creates a connection and statement object\r\n\t\t\t\tConnection conn = DriverManager.getConnection(\"jdbc:mysql://localhost:3306/PoisedPMS\",\"poisedpms\",\"poisedpms\");\r\n\t\t\t\t\r\n\t\t\t\tStatement stmt = conn.createStatement();\r\n\t\t\t\t\r\n\t\t\t){\r\n\t\t\tScanner input = new Scanner(System.in);\r\n\t\t\r\n\t\t\tSystem.out.println(\"Project Name: \");\r\n\t\t\tString project_name = input.nextLine();\r\n\t\t\r\n\t\t\tString strSelectProject = String.format(\"SELECT * FROM projects INNER JOIN project_statuses ON \"\r\n\t\t\t\t\t+ \"projects.project_id = project_statuses.project_id;\");\r\n\t\t\tResultSet project_rset = stmt.executeQuery(strSelectProject);\r\n\t\t\t\r\n\t\t\tfetch_all_project_info(stmt, project_name, project_rset);\r\n\t\t/**\r\n\t\t * @exception If entered project name cannot be found in the projects table then an SQLException is thrown\r\n\t\t */\t\t\r\n\t\t} catch ( SQLException ex ) {\r\n\t\t\tex . printStackTrace ();\r\n\t\t}\r\n\t}", "@Override\n\tpublic JSONArray searchData(String queryString)throws Exception { CALL DAO get database data\n\t\t//\n\t\ttry {\n\t\t\tJSONArray result=new JSONArray();\n\t\t\t//return null;\n result=testDB.getDataFromDB(queryString);\n\t\t\t//System.out.print(result.toString());\n\t\t\treturn result;\n\t\t\t//throw new Exception(\"Test Exception\");\n\t\t}catch(Exception e) {\n\t\t\tthrow e;\n\t\t}\n\t}", "public interface ActivityEnrollmentMapper {\n @Select(\"select status from activity_enrollment where userId=${userId} and activityId=${actId} limit 1\")\n public Integer getEnrollStatus(@Param(\"userId\") Integer userId, @Param(\"actId\") Integer actId);\n\n}", "SysCode selectByPrimaryKey(String id);", "public void getSelectedGame(int bin){\r\n try{\r\n c = DbConnect.getConnection();\r\n pstmt = c.prepareStatement(\"Select serial FROM tickets WHERE Bin = ?\");\r\n pstmt.setInt(1,bin);\r\n rs = pstmt.executeQuery();\r\n rs.next();\r\n }catch (Exception e) { e.printStackTrace(); }\r\n}", "public LearningResultHasActivity[] findWhereVersionEquals(String version) throws LearningResultHasActivityDaoException;", "TestEnum selectByPrimaryKey(String id);", "public void testFindByEstado() {\n// Iterable<Servico> servicos = repo.findByEstado(EstadoEspecificacao.INCOMPLETO, NrMecanografico.valueOf(\"1001\"));\n// servicos.forEach(s -> System.out.println(s.identity()));\n }", "public boolean cambioEstadoPorProg(Integer progPk) {\n if (progPk != null) {\n// String queryStr = \"SELECT p.proyPk\"\n// + \" FROM Proyectos p INNER JOIN p.proyEstPendienteFk estPend\"\n// + \" WHERE p.proyProgFk.progPk = :progPk\"\n// + \" AND p.proyEstPendienteFk IS NOT NULL\"\n// + \" AND p.activo = TRUE\";\n String queryStr = \"SELECT p.proyPk\"\n + \" FROM Proyectos p INNER JOIN p.proyEstPendienteFk estPend\"\n + \" WHERE p.proyProgFk.progPk = :progPk\"\n + \" AND estPend IS NOT NULL\"\n + \" AND p.proyEstFk.estCodigo IN (:codigos)\"\n + \" AND p.activo = TRUE\";\n\n Query query = getEm().createQuery(queryStr);\n query.setParameter(\"progPk\", progPk);\n query.setParameter(\"codigos\", Arrays.asList(\"INICIO\", \"PLANIFICACION\", \"EJECUCION\", \"FINALIZADO\", \"PENDIENTE_PMOT\", \"PENDIENTE_PMOF\"));\n\n return !query.getResultList().isEmpty();\n }\n return false;\n }", "@SuppressWarnings(\"unused\")\n@Repository\npublic interface PmCorMeasureStatesRepository extends JpaRepository<PmCorMeasureStates, Long> {\n PmCorMeasureStates findByCode(String code);\n\n}", "SwipersDO selectByPrimaryKey(Integer id);", "SmsEmployeeTeam selectByPrimaryKey(String id);", "public UsState[] findByDynamicWhere(String sql, Object[] sqlParams) throws UsStateDaoException;", "List<TypeTreatmentPlanStatuses> search(String query);", "private void searchFunction() {\n\t\t\r\n\t}", "private static List<String> findInforUser(String user_id, String nick) {\n\n\t//\tString[] result = new String[2];\n\t\tList<String> lstInfor = new ArrayList<String>();\n\t\tConnection connection = null;\n\t\tPreparedStatement statement = null;\n\t\tResultSet rs = null;\n\n\t\tDBPool dbpool = new DBPool();\n\n\t\ttry {\n\t\t\tconnection = dbpool.getConnection(\"VOVTV\");\n\t\t\tif (connection == null) {\n\t\t\t\tUtil.logger.error(\"Impossible to connect to DB\");\n\t\t\t\treturn lstInfor;\n\t\t\t}\n\n\t\t\t/*String sqlSelect = \"SELECT MSISDN,SexID,Brithday, Address,Favorites FROM [VOVTV].[dbo].NickName WHERE MSISDN LIKE '\"\n\t\t\t\t\t+ user_id + \"' and NickName LIKE '\"+nick+\"'\";*/\n\t\t\tString sqlSelect = \"SELECT MSISDN,SexID,Brithday, Address,Favorites FROM [dbo].NickName WHERE NickName LIKE '\"+nick+\"'\";\n\n\t\t\tUtil.logger.info(\"SEARCH INFOR : \" + sqlSelect);\n\t\t\t/*statement = connection.prepareStatement(sqlSelect);\n\t\t\tUtil.logger.info(\"SEARCH THEO BIRTHDAY AND ADDRESS\");\n\t\t\tif (statement.execute()) {\n\t\t\t\trs = statement.getResultSet();\n\t\t\t\twhile (rs.next()) {\n\t\t\t\t\tresult = Integer.valueOf(rs.getString(1));\n\t\t\t\t\t//result[1] = rs.getString(2);\n\t\t\t\t}\n\t\t\t}*/\n\t\t\t\n\t\t\tVector result = DBUtil.getVectorTable(connection, sqlSelect);\n\n\t\t\tUtil.logger.info(\"DBUtil.getCode: queryStatement:\" + sqlSelect);\n\n\t\t\tif (result.size() > 0) {\n\t\t\t\tVector item = (Vector) result.elementAt(0);\n\t\t\t\tString msisdn = item.elementAt(0).toString();\n\t\t\t\tString sexid = item.elementAt(1).toString();\n\t\t\t\tString birthday = item.elementAt(2).toString();\n\t\t\t\tString address = item.elementAt(3).toString();\n\t\t\t\tString favorites = item.elementAt(4).toString();\n\t\t\t\tlstInfor.add(msisdn);\n\t\t\t\tString gt = \"\";\n\t\t\t\tif(sexid.equalsIgnoreCase(\"1\")) {\n\t\t\t\t\tgt = \"NAM\";\n\t\t\t\t} else {\n\t\t\t\t\tgt = \"NU\";\n\t\t\t\t}\n\t\t\t\tlstInfor.add(gt);\n\t\t\t\tlstInfor.add(birthday);\n\t\t\t\tlstInfor.add(address);\n\t\t\t\tlstInfor.add(favorites);\n\t\t\t\treturn lstInfor;\n\t\t\t}\n\t\t} catch (SQLException e) {\n\t\t\tUtil.logger.error(\": Error:\" + e.toString());\n\t\t\treturn lstInfor;\n\t\t} catch (Exception e) {\n\t\t\tUtil.logger.error(\": Error:\" + e.toString());\n\t\t\treturn lstInfor;\n\t\t} finally {\n\t\t\tdbpool.cleanup(rs);\n\t\t\tdbpool.cleanup(statement);\n\t\t\tdbpool.cleanup(connection);\n\t\t}\n\t\treturn lstInfor;\n\t}", "@Transactional(propagation = Propagation.REQUIRED, readOnly = true)\n\tpublic List<Test> searchTest(final Test test){\n\t\tList<Test> result = null;\n\t\ttry{\n\t\t\tCriteria c = dao.getSession().createCriteria(Test.class,\"t\");\n\t\t\t//Criteria c = tempC2.createCriteria(\"Test\");\n\n\t\t\t//.add(Restrictions.eqProperty(\"r.testId\",\"t.id\"))\n\t\t\t//.add(Restrictions.eqProperty(\"t.projectId\",\"p.id\"));\n\t\t\t//for project properties\n\t\t\tParamChecker pc = new ParamChecker();\n\t\t\tProject project = test.getProject();\n\t\t\tif (project != null) {\n\t\t\t\tc.createAlias(\"t.project\", \"p\");\n\n\t\t\t\tif (pc.isFollowPattern(pc.UUID, project.getId())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.id\", project.getId()));\n\t\t\t\t}\n\t\t\t\tif (pc.isNotEmpty(project.getCategory())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.category\", project.getCategory()));\n\t\t\t\t}\n\t\t\t\tif (pc.isNotEmpty(project.getCountry())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.country\", project.getCountry()));\n\t\t\t\t}\n\t\t\t\tif (pc.isNotEmpty(project.getLeader())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.leader\", project.getLeader()));\n\t\t\t\t}\n\t\t\t\tif (pc.isNotEmpty(project.getPod())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.pod\", project.getPod()));\n\t\t\t\t}\n\t\t\t\tif (project.getTargetTestcaseNumber()!=null) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.targetTestcaseNumber\", project.getTargetTestcaseNumber()));\n\t\t\t\t}\n\t\t\t\tif (pc.isNotEmpty(project.getProductCode())) {\n\t\t\t\t\tc.add(Restrictions.eq(\"p.productCode\", project.getProductCode()));\n\t\t\t\t}\n\t\t\t}\n\t\t\tif (pc.isFollowPattern(pc.UUID, test.getId())){\n\t\t\t\tc.add(Restrictions.ilike(\"id\", \"%\"+test.getId()+\"%\"));\n\t\t\t}\n\t\t\tif (pc.isNotEmpty(test.getName())){\n\t\t\t\tc.add(Restrictions.ilike(\"name\", \"%\"+test.getName()+\"%\"));\n\t\t\t}\n\t\t\tif (pc.isNotEmpty(test.getDescription())){\n\t\t\t\tc.add(Restrictions.ilike(\"description\", \"%\"+test.getDescription()+\"%\"));\n\t\t\t}\n\n//\t\t\tc.add(Restrictions.isNull(\"endTime\"));\n//\t\t\tc.add(Restrictions.isNotNull(\"startTime\"));\n//\t\t\tc.addOrder(Order.desc(\"startTime\"));\n\t\t\t//criteria.setMaxResults(1);\n\n\t\t\tresult = c.list();\n\t\t\tif (result != null && result.size()>0){\n\t\t\t\treturn result;\n\t\t\t}\n\t\t} catch (Exception e){\n\t\t\te.printStackTrace();\n\t\t\tlog.error(\"Error searching for test \", e);\n\n\t\t}\n\t\treturn null;\n\t}", "public static ru.terralink.mvideo.sap.Orders findByPrimaryKey(java.lang.String IV_FO_TOR_ID\n ,java.lang.String IV_FU_TOR_ID)\n {\n String intervalName = null;\n if(com.sybase.mobile.util.perf.impl.PerformanceAgentServiceImpl.isEnabled)\n {\n intervalName = \"Orders.findByPrimaryKey\";\n com.sybase.mobile.util.perf.impl.PerformanceAgentServiceImpl.getInstance().startInterval(intervalName, com.sybase.mobile.util.perf.impl.PerformanceAgentServiceImpl.PersistenceRead);\n }\n try\n {\n \n \n String _selectSQL = \"SELECT x.\\\"a\\\",x.\\\"b\\\",x.\\\"c\\\",x.\\\"d\\\",x.\\\"e\\\",x.\\\"f\\\",x.\\\"g\\\",x.\\\"h\\\",x.\\\"i\\\",x.\\\"j\\\",x.\\\"l\\\",x.\\\"m\\\",x.\\\"n\\\",x.\\\"o\\\",x.\\\"p\\\",x.\\\"q\\\",x.\\\"r\\\",x.\\\"s\\\",x.\\\"t\\\",x.\\\"u\\\",x.\\\"v\\\",x.\\\"w\\\",x.\\\"x\\\",x.\\\"y\\\",x.\\\"z\\\",x.\\\"ba\\\",x.\\\"bb\\\",x.\\\"bc\\\",x.\\\"bd\\\",x.\\\"be\\\",x.\\\"bf\\\",x.\\\"bg\\\",x.\\\"bh\\\",x.\\\"bi\\\",x.\\\"bj\\\",x.\\\"bl\\\",x.\\\"bm\\\",x.\\\"pending\\\",x.\\\"_pc\\\",x.\\\"_rp\\\",x\"\n + \".\\\"_rf\\\",x.\\\"relationsFK\\\",x.\\\"bn\\\",x.\\\"_rc\\\",x.\\\"_ds\\\",x.\\\"cvpOperation_length\\\",x.\\\"cvpOperationLobs_length\\\" FROM \\\"mvideo5_1_0_orders\\\" x WHERE (((x.\\\"pending\\\" = 1 or not exists (select x_os.\\\"bn\\\" from \\\"mvideo5_1_0_orders_os\\\" x_os where x_os.\\\"bn\\\" = x.\\\"bn\\\")))) and ( x.\\\"bl\\\" = ? AND x.\\\"bm\\\" = ?)\";\n String[] ids = new String[0];\n com.sybase.reflection.DataType[] dts = new com.sybase.reflection.DataType[]{ \n com.sybase.reflection.DataType.forName(\"string\"),\n com.sybase.reflection.DataType.forName(\"string\"),\n };\n Object[] values = new Object[] { \n IV_FO_TOR_ID,\n IV_FU_TOR_ID,\n };\n Object res = DELEGATE.findWithSQL(_selectSQL, dts, values, ids, ru.terralink.mvideo.sap.Orders.class);\n return (ru.terralink.mvideo.sap.Orders)res;\n }\n finally\n {\n if(com.sybase.mobile.util.perf.impl.PerformanceAgentServiceImpl.isEnabled)\n {\n com.sybase.mobile.util.perf.impl.PerformanceAgentServiceImpl.getInstance().stopInterval(intervalName);\n }\n }\n }", "public interface VideoDataRepository extends CrudRepository<VideoData, Long> {\n\n /**\n * find videos\n * @param recorderInfo\n * @return\n */\n public List<VideoData> findByRecorderInfo(RecorderInfo recorderInfo);\n}" ]
[ "0.60779333", "0.58059543", "0.5758348", "0.5624857", "0.5400799", "0.5400237", "0.5351253", "0.53212667", "0.52777624", "0.5270068", "0.5242715", "0.5234195", "0.5233704", "0.5201614", "0.5178712", "0.5178329", "0.51683414", "0.516445", "0.5136346", "0.511166", "0.5104401", "0.5099572", "0.50578576", "0.50575656", "0.5056338", "0.50440603", "0.50409454", "0.50275177", "0.501666", "0.499857", "0.4992143", "0.49827912", "0.49719292", "0.4970885", "0.49681515", "0.49666792", "0.49607962", "0.49556154", "0.49529108", "0.4938726", "0.4936227", "0.4928512", "0.4926775", "0.49246347", "0.4915821", "0.48998487", "0.48990762", "0.48981935", "0.48931485", "0.4891279", "0.48903552", "0.48901471", "0.4889051", "0.48874173", "0.48874122", "0.48866367", "0.48820516", "0.48759001", "0.4875547", "0.48754254", "0.48728547", "0.48697174", "0.4866458", "0.4857498", "0.48568624", "0.48527923", "0.48523983", "0.48517263", "0.48511013", "0.48401427", "0.48389214", "0.48348832", "0.48340997", "0.48330626", "0.4823264", "0.4817559", "0.48150888", "0.48135117", "0.48113853", "0.48077095", "0.48020867", "0.4800134", "0.47977847", "0.47927693", "0.47925004", "0.47902963", "0.47895554", "0.4789367", "0.47865662", "0.4783417", "0.47827968", "0.47819906", "0.47787207", "0.47786632", "0.47764298", "0.47756058", "0.47711384", "0.47688115", "0.47686726", "0.4768413" ]
0.6423791
0
auths not ready at this time The purpose of Dao method is to perform save operation of IPATestStage noun into database
@Transactional public IPATestStage create_ipateststage(IPATestStage IPATestStage, IPUser user) throws Exception { log.setLevel(Level.INFO); log.info("create_ipateststage Dao started operation!"); try{ Query query = entityManager .createNativeQuery(create_IPATestStage) .setParameter("name", IPATestStage.getName()) .setParameter("created_by", user == null ? 0:user.getId()) .setParameter("updated_by", user == null ? 0:user.getId()) ; int insertedId = query.executeUpdate(); String lastIndex="select last_insert_id()"; Query sql = entityManager.createNativeQuery(lastIndex); BigInteger new_id = (BigInteger) sql.getSingleResult(); IPATestStage.setId(new_id.longValue()); System.out.println("create data---"+insertedId); log.info("Object returned from create_ipateststage Dao method !"); return IPATestStage; }catch(Exception e){ //System.out.println("DAOException: " + e.toString()); log.error(" Dao method (create_ipateststage) throws Exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Transactional\n\tpublic TestNoun create_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"create_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(create_TestNoun)\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"created_by\", user == null ? 0:user.getId())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tint insertedId = query.executeUpdate();\n\t\t\t\t\tString lastIndex=\"select last_insert_id()\";\n\t\t\t\t\tQuery sql = entityManager.createNativeQuery(lastIndex);\n\t\t\t\t\tBigInteger new_id = (BigInteger) sql.getSingleResult();\n\t\t\t\t\tTestNoun.setId(new_id.longValue());\n\t\t\t\t\tSystem.out.println(\"create data---\"+insertedId);\n\n\t\t\tlog.info(\"Object returned from create_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (create_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public void save(PtJJdwcy entity);", "int insert(ActivityHongbaoPrize record);", "public void save() {\r\n\t\tCampLeaseDAO leaseDao = (CampLeaseDAO) getApplicationContext().getBean(\"leaseDaoBean\", CampLeaseDAO.class);\r\n\t\tleaseDao.save(this);\r\n\t}", "int insert(AnnouncementDO record);", "public void saveOneWord(Pojo.OneWord e){ \n template.save(e); \n}", "@Override\r\n\tpublic void save() {\n\r\n\t\ts.save();\r\n\r\n\t}", "void SaveInvPreFileDetailDao(InvPreFileDetailEntity invPreFileDetailEntity);", "private void addSomeItemsToDB () throws Exception {\n/*\n Position pos;\n Course course;\n Ingredient ing;\n\n PositionDAO posdao = new PositionDAO();\n CourseDAO coursedao = new CourseDAO();\n IngredientDAO ingdao = new IngredientDAO();\n\n ing = new Ingredient(\"Mozzarella\", 10,30);\n ingdao.insert(ing);\n\n // Salads, Desserts, Main course, Drinks\n pos = new Position(\"Pizza\");\n posdao.insert(pos);\n\n course = new Course(\"Salads\", \"Greek\", \"Cucumber\", \"Tomato\", \"Feta\");\n coursedao.insert(course);\n\n ing = new Ingredient(\"-\", 0,0);\n ingdao.insert(ing);\n */\n }", "int insert(AutoAssessDetailWithBLOBs record);", "int insert(Storydetail record);", "int insert(PrefecturesMt record);", "public void insert1(login uv) {\n\t\ttry\n {\n SessionFactory sessionFactory = new AnnotationConfiguration().configure().buildSessionFactory();\n \t\n Session session = sessionFactory.openSession();\n \n Transaction transaction=session.beginTransaction();\n \n session.save(uv);\n \n transaction.commit();\n \n session.close();\n }\n catch(Exception ex)\n {\n ex.printStackTrace();\n }\n\t\t\n\t}", "int insert(GoodsPo record);", "private void saveAT() \n {\n // get DatabaseConnector to interact with the SQLite database\n\t AnimalDatabase db = new AnimalDatabase(this);\n\t AnimalList al = new AnimalList (db);\n\t \n // insert the contact information into the database\n al.Update(id, amount, comments);\n\n }", "int insert(PmPost record);", "@Override\n public void save(Seq s) {\n // TODO Auto-generated method stub\n \t//Establish cnx\n\t\tConnection conn = null;\n\t\tString url = \"jdbc:sqlite:src\\\\database\\\\AT2_Mobile.db\";\n\t\t\n\t\ttry {\n\t\t\tconn = DriverManager.getConnection(url);\n\t\t\tPreparedStatement myStmt; \n\t\t\tString query = \"insert into seq(identifier, seq_number) values(?,?)\";\n\t\t\tmyStmt = conn.prepareStatement(query);\n\t\t\t\n\t\t\t// Set Parameters\n\t myStmt.setString(1, s.getProcess().getIdentifier());\n\t myStmt.setInt(2, s.getSeq_number());\n\t\t\t// Execute SQL query\n\t int res = myStmt.executeUpdate();\n\t \n\t // Display the record inserted\n\t System.out.println(res + \" Seq inserted\\n\");\n\t \n\t // Close the connection\n\t conn.close();\n\t\t}catch (SQLException e) {\n\t\t\tSystem.out.println(e.getMessage());}\n\t\t\n\t\tfinally {\n\t\t\ttry {\n\t\t\t\tif (conn != null) {\n\t\t\t\t\tconn.close();\n\t\t\t\t}\n\t\t\t} catch (SQLException ex) {\n\t\t\t\tSystem.out.println(ex.getMessage());\n\t\t\t}\n\t\t\t}\n }", "void insert(VRpWkProvinceGprsCsBh record);", "@Test\r\n\tpublic void addToDb() {\r\n\t\tservice.save(opinion);\r\n\t\tassertNotEquals(opinion.getId(), 0);\r\n\t\tassertTrue(service.exists(opinion.getId()));\r\n\t}", "int insert(Ltsprojectpo record);", "Persistencia() {\n\t}", "int insert(InspectionAgency record);", "@Override\n public void onClick(View view) {\n Log.d(\"CALL_TEST\", \"SAVE!\");\n DbManager db = DbManager.getInstance(getApplicationContext());\n\n ContentValues contentValues = new ContentValues();\n contentValues.put(\"NAME\", \"홍길동\");\n contentValues.put(\"PHONE\", \"1234\");\n\n db.insert(contentValues);\n }", "Post save(Post post) throws Exception;", "public final /* synthetic */ void saveToDb() {\n DruidPooledConnection druidPooledConnection;\n DruidPooledConnection druidPooledConnection2;\n block18: {\n block17: {\n StringBuilder stringBuilder;\n PreparedStatement preparedStatement;\n MaplePet a2;\n if (!a2.a) {\n return;\n }\n try {\n druidPooledConnection2 = DBConPool.getInstance().getDataSource().getConnection();\n try {\n preparedStatement = druidPooledConnection2.prepareStatement(ConcurrentEnumMap.ALLATORIxDEMO(\";\\t*\\u0018:\\u001cN)\\u000b-\\u001dy=\\u001c:y\\u00008\\u0003<NdNfBy\\u0002<\\u0018<\\u0002ySyQuN:\\u00026\\u001d<\\u0000<\\u001d*NdNfBy\\b,\\u00025\\u0000<\\u001d*NdNfBy\\u001d<\\r6\\u0000=\\u001dySyQuN?\\u00028\\t*NdNfBy\\u000b!\\r5\\u001b=\\u000b=NdNfNuN*\\u001e<\\u000b=NdNfBy\\f,\\b?\\u001d2\\u00075\\u00020\\nySyQuN:\\u000f7>0\\r2;)NdNfBy\\u001d2\\u00075\\u00020\\nySyQy9\\u0011+\\u000b+y\\u001e<\\u001a0\\nySyQ\"));\n try {\n int n2;\n PreparedStatement preparedStatement2 = preparedStatement;\n PreparedStatement preparedStatement3 = preparedStatement;\n preparedStatement.setString(1, a2.h);\n preparedStatement3.setByte(2, a2.e);\n preparedStatement3.setShort(3, a2.B);\n preparedStatement2.setByte(4, a2.H);\n preparedStatement2.setInt(5, a2.J);\n preparedStatement.setShort(6, a2.k);\n stringBuilder = new StringBuilder();\n int n3 = n2 = 0;\n while (n3 < a2.d.length) {\n stringBuilder.append(a2.d[n2]);\n stringBuilder.append(KoreanDateUtil.ALLATORIxDEMO(\"V\"));\n n3 = ++n2;\n }\n }\n catch (Throwable throwable) {\n Throwable throwable2;\n if (preparedStatement != null) {\n try {\n preparedStatement.close();\n throwable2 = throwable;\n throw throwable2;\n }\n catch (Throwable throwable3) {\n throwable.addSuppressed(throwable3);\n }\n }\n throwable2 = throwable;\n throw throwable2;\n }\n }\n catch (Throwable throwable) {\n Throwable throwable4;\n if (druidPooledConnection2 != null) {\n try {\n druidPooledConnection2.close();\n throwable4 = throwable;\n throw throwable4;\n }\n catch (Throwable throwable5) {\n throwable.addSuppressed(throwable5);\n }\n }\n throwable4 = throwable;\n throw throwable4;\n }\n }\n catch (SQLException sQLException) {\n FilePrinter.printError(ConcurrentEnumMap.ALLATORIxDEMO(\"\\u0014\\u000f)\\u0002<><\\u001aw\\u001a!\\u001a\"), sQLException, KoreanDateUtil.ALLATORIxDEMO(\"e\\u001b`\\u001fB\\u0015R\\u0018\"));\n return;\n }\n {\n String string = stringBuilder.toString();\n PreparedStatement preparedStatement4 = preparedStatement;\n PreparedStatement preparedStatement5 = preparedStatement;\n PreparedStatement preparedStatement6 = preparedStatement;\n String string2 = string;\n preparedStatement6.setString(7, string2.substring(0, string2.length() - 1));\n preparedStatement6.setInt(8, a2.ALLATORIxDEMO);\n preparedStatement5.setInt(9, a2.I);\n preparedStatement5.setShort(10, a2.K);\n preparedStatement4.setInt(11, a2.M);\n preparedStatement4.setInt(12, a2.D);\n preparedStatement4.executeUpdate();\n a2.a = false;\n if (preparedStatement == null) break block17;\n druidPooledConnection = druidPooledConnection2;\n }\n preparedStatement.close();\n break block18;\n }\n druidPooledConnection = druidPooledConnection2;\n }\n if (druidPooledConnection == null) return;\n druidPooledConnection2.close();\n }", "int insert(AccessModelEntity record);", "int insertSelective(ActivityHongbaoPrize record);", "int insert(countrylanguage record);", "int insert(TestActivityEntity record);", "@Override\r\n\tpublic void save(TQssql sql) {\n\r\n\t}", "int insertSelective(AnnouncementDO record);", "public void save() {\n\t\tSystem.out.println(\"-----------from PersonDao.save()\");\n\t}", "int insert(ArticleDo record);", "void save() {\n gameModelPoDao.saveToFile(file.getAbsolutePath(), gameModelPo);\n }", "public static int save(Periode p){ \n int status=0; \n try{ \n //membuka koneksi\n Connection con=Koneksi.openConnection();\n //melakukan query database\n PreparedStatement ps=con.prepareStatement( \n \"insert into periode(tahun, awal, akhir) values(?,?,?)\"); \n ps.setString(1,p.getTahun()); \n ps.setString(2,p.getAwal()); \n ps.setString(3,p.getAkhir()); \n status=ps.executeUpdate(); \n }catch(Exception e){\n System.out.println(e);\n } \n return status; \n }", "int insert(TrainingCourse record);", "int insert(CmsVoteTitle record);", "int insert(ProcurementSource record);", "public void saveToFile(View view) {\n //Insert the word into the Database\n try {\n //Insert the word and definition into the database\n DefinitionsViewModel dvm = ViewModelProviders.of(this).get(DefinitionsViewModel.class);\n dvm.insert(new Definitions(queryString, shortDef));\n\n //Let the user know the operation was successful\n Toast.makeText(this, getString(R.string.saveSuccessMessage), Toast.LENGTH_SHORT).show();\n } catch (Exception e) {\n e.printStackTrace();\n //Let the user know that the operation failed.\n Toast.makeText(this, getString(R.string.saveFailedMessage), Toast.LENGTH_SHORT);\n\n\n }\n\n }", "@Override\n\tpublic void save() {\n\t\tSystem.out.println(\"UserDao实现类\");\n\t}", "int insert(ReleaseSystem record);", "void savePost(Post post);", "public void save()\n\t{\t\n\t\tfor (Preis p : items) {\n\t\t\titmDAO.create(p.getItem());\n\t\t\tprcDAO.create(p);\n\t\t}\n\t\tstrDAO.create(this);\n\t}", "int insert(PmKeyDbObj record);", "@Override\n\tpublic void save(CorsoDiLaurea corso) {\n\t\t\n\t}", "EmployeeDetail save(EmployeeDetail detail) throws DBException;", "public void databaseinsert() {\n\n\t\tStringBuilder sb = new StringBuilder();\n\t\tSite site = new Site(Sid.getText().toString().trim(), Scou.getText().toString().trim());\n\t\tlong rowId = dbHlp.insertDB(site);\n\t\tif (rowId != -1) {\n\t\t\tsb.append(getString(R.string.insert_success));\n\n\t\t} else {\n\n\t\t\tsb.append(getString(R.string.insert_fail));\n\t\t}\n\t\tToast.makeText(Stu_state.this, sb, Toast.LENGTH_SHORT).show();\n\t}", "@Override\r\npublic int create(Detalle_pedido d) {\n\treturn detalle_pedidoDao.create(d);\r\n}", "@Override\r\n\tpublic void save() {\n\r\n\t}", "@Override\r\n\tpublic void save() {\n\r\n\t}", "@Override\n public void save()\n {\n \n }", "private void insertData() {\n PodamFactory factory = new PodamFactoryImpl();\n for (int i = 0; i < 3; i++) {\n ViajeroEntity entity = factory.manufacturePojo(ViajeroEntity.class);\n\n em.persist(entity);\n data.add(entity);\n }\n }", "@Override\n public void save() {\n \n }", "int insertSelective(PrefecturesMt record);", "int insert(UserPonumberGoods record);", "@Insert({\n \"insert into dept (id, dept_name)\",\n \"values (#{id,jdbcType=INTEGER}, #{deptName,jdbcType=VARCHAR})\"\n })\n int insert(Dept record);", "public void insert1(DocumentDetails docDetails) {\n Session session = HibernateUtil.getSessionFactory().openSession();\n Transaction tx = null;\n try {\n tx = session.beginTransaction();\n session.save(docDetails);\n tx.commit();\n } catch (RuntimeException e) {\n \n tx.rollback();\n e.printStackTrace();\n } finally {\n session.close();\n }\n }", "int insert(BlogDetails record);", "protected void activitySaveInDb(CustomApplicationInfo cai) {\n\t\tinitDb();\n\t\tdbAccess.insert(cai);\n\t}", "int insert(PayLogInfoPo record);", "public void insertDB() {\n sql = \"Insert into Order (OrderID, CustomerID, Status) VALUES ('\"+getCustomerID()+\"','\"+getCustomerID()+\"', '\"+getStatus()+\"')\";\n db.insertDB(sql);\n \n }", "public void testSalvar() {\r\n Dao dao = new DaoTag();\r\n Tag tag = new Tag(\"660,260,\\\"imaginary world, characters, story, philosophical\\\",1436680217\");\r\n System.out.println(tag.getMovieId()+\",\"+tag.getTag()+\",\"+tag.getUserId()+\",\"+tag.getTimestamp());\r\n }", "private void pushToHibernate(){\n DATA_API.saveUser(USER);\n }", "public void save() throws Exception{\n\t\tm_service = new DistrictService();\n\t\t//插入城市\t\t\n\t\t//String saveStr = \"~`哈迪~`达鲁~`哥本~`~`~`C~`9898~`9898~`0~`~`0~`~`从DHL地区表中导入~`N~`N~`N~`~`~`~`~`~`~`EMS~`~`~@~#\";\t\n\t\t//插入国家\n\t\tString saveStr = \"3785~`麦克1~`纽斯1~`迪录1~`~`~`C~`9898~`9898~`0~`~`0~`~`从DHL地区表中导入~`N~`N~`N~`1~`~`~`~`~`~`EMS~`~`~@~#\";\t\n\n\t\tDecoder objPD = new Decoder(saveStr);\n\t\tString objReturn = m_service.save(objPD);\n\t\tSystem.out.println(objReturn);\n\t\t\n\t}", "int insert(ArticleTag record);", "@Override\n\tpublic void save() {\n\t\t\n\t}", "@Override\n\tpublic void save() {\n\t\t\n\t}", "@Override\n\tpublic void save(Domingo domingo) {\n\t\tdomingoDAO.save(domingo);\t\t\n\t}", "private DatabaseCustomAccess(Context context) {\n\t\thelper = new SpokaneValleyDatabaseHelper(context);\n\n\t\tsaveInitialPoolLocation(); // save initial pools into database\n\t\tsaveInitialTotalScore(); // create total score in database\n\t\tsaveInitialGameLocation(); // create game location for GPS checking\n\t\tLoadingDatabaseTotalScore();\n\t\tLoadingDatabaseScores();\n\t\tLoadingDatabaseGameLocation();\n\t}", "public interface RequestPramDao {\n void insert(RequestPram requestPram);\n}", "int insert(SysTeam record);", "int insert(SwipersDO record);", "int insert(Tourst record);", "public void insere(Pessoa pessoa){\n\t\tdb.save(pessoa);\n\t}", "private void insertData() {\n PodamFactory factory = new PodamFactoryImpl();\n for (int i = 0; i < 3; i++) {\n VueltasConDemoraEnOficinaEntity entity = factory.manufacturePojo(VueltasConDemoraEnOficinaEntity.class);\n \n em.persist(entity);\n data.add(entity);\n }\n }", "int insert(Kaiwa record);", "@Override\n public void save() {\n\n }", "@Override\r\n\tpublic void add(snstatus sns) {\n\t\tsuper.getHibernateTemplate().save(sns); \r\n\t}", "int insertSelective(AutoAssessDetailWithBLOBs record);", "int insert(PrescriptionVerifyRecordDetail record);", "@Override\r\n\tpublic void save(Plate tipo) {\n\t\t\r\n\t}", "@Override\n @Transactional\n public void onSubmit() {\n ValueMap values = getModelObject();\n\n // check if the honey pot is filled\n if (StringUtils.isNotBlank((String)values.get(\"comment\")))\n {\n error(\"Caught a spammer!!!\");\n return;\n }\n // Construct a copy of the edited comment\n Snip snip = new Snip();\n SnipMeta meta= new SnipMeta();\n\n logger.info(this.getDefaultModel().toString());\n\n logger.info(((List<String>) values.get(\"select_all\")).toString());\n\n meta.setTags((ArrayList<String>)values.get(\"select_all\"));\n meta.setDescription((String) values.get(\"meta\"));\n\n\n // Set date of comment to add\n snip.setDate(new Date());\n snip.setCode((String)values.get(\"code\"));\n snipList.add(0, snip); //TODO: eliminare lo show di tutti gli snipp da snipList magari con una FIFO\n meta.setSnip(snip);\n\n\n //--------- get session ad manager ------\n MyAuthenticatedWebSession app_session = MyAuthenticatedWebSession.getYourAppSession();\n logger.info(\"web session is: \"+app_session.toString());\n EntityManager em = app_session.getEntityManager();\n //---------------------------------------------------\n\n Users tmp_id = em.find(Users.class ,app_session.getAttribute(\"user\"));\n //snip.setUser(app_session.getCurrentUser()); --less network more backend\n snip.setUser(tmp_id);\n em.getTransaction().begin();\n em.setFlushMode(COMMIT);\n em.persist(snip);\n em.persist(meta);\n em.flush();\n em.getTransaction().commit();\n\n\n // Clear out the text component\n values.put(\"code\", \"\");\n }", "@Override\n public void doTaskWorkPostSave(HttpServletRequest request, HttpServletResponse response, User user, Db db)\n {\n\t updateAppFilesWithAppliesTo(request, response, user, db);\n\t //if(strains.isEmpty())\n\t //{\n\t\t // single strain\n\t updateCustomTables(request, db);\n\t //}\n\t //else\n\t //{\n\t\t // list of strains from bulk import file\n\t\t// updateCustomTablesWithList(db);\n\t //}\n }", "public void saveInwDepartCompetence(InwDepartCompetence inwDepartCompetence);", "int insert(Prueba record);", "int insert(UserOperateProject record);", "int insertSelective(GoodsPo record);", "private void updateDB() {\n }", "private void insertData() {\r\n \r\n TeatroEntity teatro = factory.manufacturePojo(TeatroEntity.class);\r\n em.persist(teatro);\r\n FuncionEntity funcion = factory.manufacturePojo(FuncionEntity.class);\r\n List<FuncionEntity> lista = new ArrayList();\r\n lista.add(funcion);\r\n em.persist(funcion);\r\n for (int i = 0; i < 3; i++) \r\n {\r\n SalaEntity sala = factory.manufacturePojo(SalaEntity.class);\r\n sala.setTeatro(teatro);\r\n sala.setFuncion(lista);\r\n em.persist(sala);\r\n data.add(sala);\r\n }\r\n for (int i = 0; i < 3; i++) \r\n {\r\n SalaEntity sala = factory.manufacturePojo(SalaEntity.class);\r\n sala.setTeatro(teatro);\r\n em.persist(sala);\r\n sfdata.add(sala);\r\n }\r\n \r\n }", "@Override\n public void Save() {\n\t \n }", "public abstract void leerPersistencia();", "int insert(IceApp record);", "int insert(CityDO record);", "@PostConstruct\n void insertData() {\n\t\ttry {\n\t\t\tinsertDataFromJsonToDb.insertIntoDatabase();\n\t\t\tlogger.info(\"The database is filled by data\");\n\n\t\t} catch (Throwable throwable) {\n\t\t\tthrowable.printStackTrace();\n\t\t}\n\t}", "int insert(TrainCourse record);", "int insert(PaasCustomAutomationRecord record);", "@Transactional\n\tpublic TestNoun update_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"update_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(update_TestNoun)\n\t\t\t.setParameter(\"id\", TestNoun.getId())\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from update_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (update_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "private void save_word() {\n\t\tif(this.dwd!=null && this.main_word!=null)\n\t\t{\n\n\t\t\tDictCommon.SaveWord(this.main_word,isHindi);\n\t\t\tToast.makeText(view.getContext(), \"word \"+this.main_word+\" successfully saved!!!\", Toast.LENGTH_LONG).show();\n\t\t}\n\t}", "public static void main(String[] args) \r\n {\n \r\n MongoConnectionManager mongo = MongoConnectionManager.getInstance(); \r\n Datastore ds = mongo.getDatastore();\r\n \r\n AdminDAO admindao = new AdminDAO(AdminEntity.class, ds);\r\n EtudiantDAO etudiantDAO = new EtudiantDAO(EtudiantEntity.class, ds);\r\n ProfessorDAO profDao = new ProfessorDAO(ProfessorEntity.class, ds);\r\n ModuleDAO moduledao = new ModuleDAO(ModuleEntity.class, ds);\r\n ExamenDAO examenDAO = new ExamenDAO(ExamenEntity.class,ds);\r\n FiliereDAO filiereDAO = new FiliereDAO(FiliereEntity.class, ds);\r\n /*\r\n \r\n AdminEntity admin = new AdminEntity(\"jalil\", \"messaf\", \"[email protected]\", \"admin\", null, \"[[email protected]\");\r\n \r\n //admindao.save(admin);\r\n \r\n \r\n \r\n EtudiantEntity etudiant = new EtudiantEntity();\r\n etudiant.setEmail(\"[email protected]\");\r\n etudiant.setFirstName(\"anas\");\r\n \r\n etudiantDAO.updateEtudiant(etudiant);\r\n */\r\n \r\n \r\n \r\n //ProfessorEntity p = profDao.getByEmail(\"[email protected]\");\r\n //profDao.updateFieldByEmail(\"urlAvatar\",\"[[email protected]\",\"[email protected]\");\r\n /*\r\n ModuleEntity m1 = new ModuleEntity();\r\n ModuleEntity m2 = new ModuleEntity();\r\n ModuleEntity m3 = new ModuleEntity();\r\n \r\n \r\n m1 = moduledao.findByName(\"Objective C\");\r\n m2 = moduledao.findByName(\"GPI\");\r\n m3 = moduledao.findByName(\"Oracle\");\r\n \r\n \r\n long minute=60000;\r\n long hour = minute * 60;\r\n \r\n \r\n Calendar date = Calendar.getInstance();\r\n long now = date.getTimeInMillis();\r\n \r\n Date twoHoursAgo = new Date(now - 2*hour);\r\n Date twoHoursLater = new Date(now + 2*hour);\r\n */\r\n \r\n //ExamenEntity ex1 = new ExamenEntity(twoHoursAgo, twoHoursLater, m2);\r\n //moduledao.addExam(m2, ex1);\r\n \r\n //System.out.println(\"date debut : \"+twoHoursAgo);\r\n //System.out.println(\"date fin : \"+twoHoursLater);\r\n \r\n //OpEtudiant oe = new OpEtudiant();\r\n \r\n //List<ExamenEntity> list = oe.getExamEnCours(e);\r\n \r\n /*\r\n FiliereEntity filiereEntity = filiereDAO.getFiliereByname(FiliereEnum.GI);\r\n System.out.println(\"filiere\"+filiereEntity.getListModule());\r\n */\r\n //filiereDAO.addModule(filiereEntity, m);\r\n \r\n //OpEtudiant op = new OpEtudiant();\r\n \r\n //List<ExamenEntity> listExam = op.getExams();\r\n \r\n //System.out.println(\"exams : \"+listExam);\r\n \r\n \r\n //moduledao.addExam(m, ex);\r\n \r\n \r\n //m = moduledao.findByName(\"Metaeuristique\");\r\n \r\n //moduledao.updateName(\"Metaeuristique\", \"Metaeuristique 2\");\r\n \r\n \r\n //System.out.println(\"module modifié : \"+m);\r\n \r\n \r\n //p.modules.set(0, m);\r\n \r\n \r\n //profDao.updateProfessor(p);\r\n \r\n //p = profDao.getByEmail(\"[email protected]\");\r\n \r\n //profDao.addModule(p, m);\r\n \r\n //System.out.println(\"prof\"+p);\r\n //System.out.println(\"ses modules\"+p.modules);\r\n \r\n \r\n /**\r\n \r\n \r\n ModuleEntity m = moduledao.findByName(\"GPI\");\r\n \r\n System.out.println(\"module \"+m);\r\n \r\n ExamenEntity ex1 = new ExamenEntity(new Date(), m);\r\n ExamenEntity ex2 = new ExamenEntity(new Date(), m);\r\n \r\n List<ExamenEntity> examens = new ArrayList<>();\r\n examens.add(ex1);\r\n examens.add(ex2);\r\n \r\n m.setExamens(examens);\r\n **/\r\n \r\n \r\n \r\n //ProfessorEntity p = profDao.getByEmail(\"[email protected]\");\r\n \r\n \r\n /*\r\n p.setEmail(\"[email protected]\");\r\n p.setFirstName(\"prof\");\r\n p.setLastame(\"prof\");\r\n p.setPassword(\"prof\");\r\n p.setDateOfBirth(new Date());\r\n p.setUrlAvatar(\"[B@1d33e602\");\r\n \r\n ModuleEntity m1 = new ModuleEntity(\"Metaeuristique\", p);\r\n ModuleEntity m2 = new ModuleEntity(\"GPI\", p);\r\n ModuleEntity m3 = new ModuleEntity(\"Android\", p);\r\n ModuleEntity m4 = new ModuleEntity(\"Programmation System\", p);\r\n ModuleEntity m5 = new ModuleEntity(\"Oracle\", p);\r\n ModuleEntity m6 = new ModuleEntity(\"Francais\", p);\r\n ModuleEntity m7 = new ModuleEntity(\"Anglais\", p);\r\n \r\n List<ModuleEntity> list = new ArrayList<>();\r\n \r\n list.add(m1);\r\n list.add(m2);\r\n list.add(m3);\r\n list.add(m4);\r\n list.add(m5);\r\n list.add(m6);\r\n list.add(m7);\r\n \r\n \r\n \r\n FiliereEntity filiere = new FiliereEntity(FiliereEnum.GI, list);\r\n \r\n \r\n ModuleDAO moduledao = new ModuleDAO(ModuleEntity.class, ds);\r\n \r\n \r\n \r\n profDao.save(p);\r\n \r\n p.setModules(list);\r\n \r\n moduledao.save(m1);\r\n moduledao.save(m2);\r\n moduledao.save(m3);\r\n moduledao.save(m4);\r\n moduledao.save(m5);\r\n moduledao.save(m6);\r\n moduledao.save(m7);\r\n \r\n profDao.save(p);\r\n \r\n FiliereDAO filieredao = new FiliereDAO(FiliereEntity.class, ds);\r\n filieredao.save(filiere);\r\n \r\n \r\n \r\n \r\n \r\n \r\n EtudiantDAO etudiantDAO = new EtudiantDAO(EtudiantEntity.class, ds);\r\n AdminDAO adminDAO = new AdminDAO(AdminEntity.class, ds);\r\n \r\n \r\n \r\n \r\n //List<ModuleEntity> list = filieredao.getList(FiliereEnum.GI);\r\n \r\n //System.out.println(\"modules : \"+list);\r\n /*\r\n OpAdmin adminOp = new OpAdmin();\r\n \r\n List<FiliereEntity> listfFiliereEntitys = adminOp.getAllFilieres();\r\n List<ModuleEntity> listmod = listfFiliereEntitys.get(0).getListModule();\r\n \r\n System.out.println(\"modules : \"+listmod);\r\n \r\n //ProfessorEntity p = profDao.getByEmail(\"[email protected]\");\r\n \r\n //System.out.println(\"prof : \"+p);\r\n //System.out.println(\"modules : \"+p.modules);\r\n \r\n \r\n //ModuleEntity m = new ModuleEntity(\"Sport\", p);\r\n \r\n //profDao.addModuleTo(p, m);\r\n \r\n //p = profDao.getByEmail(\"[email protected]\");\r\n \r\n //System.out.println(\"after update module : \"+p.getModules());\r\n \r\n \r\n //EtudiantEntity e = etudiantDAO.findByEmail(\"[email protected]\");\r\n //System.out.println(\"etudiant : \"+e);\r\n \r\n //AdminEntity admin = adminDAO.findByEmail(\"[email protected]\");\r\n \r\n //System.out.println(\"after convert to admin metier : \"+admin.toAdmin());\r\n \r\n /*\r\n User etudiant = new Etudiant();\r\n \r\n if(etudiant instanceof Etudiant)\r\n System.out.println(\"yes\");\r\n \r\n if(etudiant instanceof Professor)\r\n System.out.println(\"no\");\r\n */\r\n \r\n Date t = new Date();\r\n \r\n \r\n //System.out.println(RandomStuff.displayBirthDay(t));\r\n \r\n \r\n \r\n }", "public void save(){\n\t\tlowresModelManager.save();\n\t}" ]
[ "0.6140679", "0.60414946", "0.601763", "0.59233874", "0.5842039", "0.58146536", "0.5745208", "0.57307225", "0.57153875", "0.5713219", "0.5710568", "0.57098603", "0.56729317", "0.5667085", "0.5661583", "0.5638747", "0.56341314", "0.5623607", "0.5608302", "0.55722266", "0.5569926", "0.55692846", "0.55639577", "0.5546222", "0.5543935", "0.55402106", "0.55366296", "0.55362177", "0.55303466", "0.55151933", "0.5513923", "0.5513476", "0.54906", "0.5484193", "0.5469962", "0.5467349", "0.5457903", "0.5450619", "0.5445636", "0.5444036", "0.54416806", "0.54398096", "0.5427803", "0.5426738", "0.54169405", "0.54155153", "0.5413849", "0.5411181", "0.5410039", "0.5410039", "0.54077256", "0.5406297", "0.5405506", "0.5394196", "0.5392452", "0.53918344", "0.53853714", "0.538408", "0.5383694", "0.5378767", "0.53714913", "0.53698874", "0.53678644", "0.5367313", "0.5367115", "0.5361506", "0.5361506", "0.53599435", "0.5359248", "0.53584915", "0.5355999", "0.5354778", "0.5354704", "0.5351753", "0.5346069", "0.5342454", "0.53410864", "0.53353834", "0.53347427", "0.5334436", "0.5333572", "0.5330242", "0.5327421", "0.53241825", "0.53241265", "0.5318312", "0.53177136", "0.5317475", "0.5312983", "0.5307502", "0.5304068", "0.5302265", "0.53018093", "0.5299562", "0.52990973", "0.5298983", "0.529714", "0.52918154", "0.52911323", "0.5290982" ]
0.53659594
65
auths not ready at this time The purpose of Dao method is to perform update operation of IPATestStage noun into database
@Transactional public IPATestStage update_ipateststage(IPATestStage IPATestStage, IPUser user) throws Exception { log.setLevel(Level.INFO); log.info("update_ipateststage Dao started operation!"); try{ Query query = entityManager .createNativeQuery(update_IPATestStage) .setParameter("id", IPATestStage.getId()) .setParameter("name", IPATestStage.getName()) .setParameter("updated_by", user == null ? 0:user.getId()) ; query.executeUpdate(); log.info("Object returned from update_ipateststage Dao method !"); return IPATestStage; }catch(Exception e){ //System.out.println("DAOException: " + e.toString()); log.error(" Dao method (update_ipateststage) throws Exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void updateDB() {\n }", "@Transactional\n\tpublic TestNoun update_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"update_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(update_TestNoun)\n\t\t\t.setParameter(\"id\", TestNoun.getId())\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from update_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (update_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "int updateByPrimaryKey(Ltsprojectpo record);", "int updateByPrimaryKey(AnnouncementDO record);", "@Test\r\n public void testUpdate() {\r\n System.out.println(\"update\");\r\n Title t = new Title();\r\n t.setIsbn(\"test\");\r\n t.setTitle(\"aaaaaaaaaaaaaaaaaa\");\r\n t.setAuthor(\"kkkkkkkkkkkkkk\");\r\n t.setType(\"E\");\r\n int expResult = 1;\r\n int result = TitleDao.update(t);\r\n assertEquals(expResult, result);\r\n }", "int updateByPrimaryKey(RepStuLearning record);", "@Override\n\t\tprotected void postUpdate(EspStatusDTO t) throws SQLException {\n\t\t\t\n\t\t}", "int updateByPrimaryKey(Disease record);", "int updateByPrimaryKey(GoodsPo record);", "@Override\r\npublic int update(Detalle_pedido d) {\n\treturn detalle_pedidoDao.update(d);\r\n}", "int updateByPrimaryKey(ActivityHongbaoPrize record);", "int updateByPrimaryKey(Tourst record);", "int updateByPrimaryKey(Prueba record);", "int updateByPrimaryKey(ProcurementSource record);", "@Override\r\npublic int updateByPrimaryKeySelective(Possalesdetail record) {\n\treturn possalesdetail.updateByPrimaryKeySelective(record);\r\n}", "int updateByPrimaryKey(Assist_table record);", "int updateByPrimaryKey(YzStiveExplosion record);", "int updateByPrimaryKey(countrylanguage record);", "private static void LessonDAOUpdate() {\n PersonDAO personDAO = new PersonDAOImpl();\n\n Person person = personDAO.getPersonById(7);\n person.setFirstName(\"Teddy\");\n\n if(personDAO.updatePerson(person)) {\n System.out.println(\"Person Update Success!\");\n } else {\n System.out.println(\"Person Update Fail!\");\n }\n }", "@Override\n public void updateDatabase() {\n }", "public void uptadeDB(){\n //mainDatabase.modifyStaff(this);\n }", "int updateByPrimaryKey(UserPonumberGoods record);", "int updateByPrimaryKey(AutoAssessDetail record);", "int updateByPrimaryKey(ArticleTag record);", "int updateByPrimaryKey(AccessModelEntity record);", "int updateByPrimaryKey(Miss_control_log record);", "int updateByPrimaryKey(SysTeam record);", "int updateByPrimaryKeySelective(AnnouncementDO record);", "int updateByPrimaryKey(DictDoseUnit record);", "int updateByPrimaryKeySelective(Ltsprojectpo record);", "int updateByPrimaryKey(CaseLinkman record);", "int updateByPrimaryKey(Caiwu record);", "int updateByPrimaryKeySelective(ActivityHongbaoPrize record);", "int updateByPrimaryKey(TCpySpouse record);", "int updateByPrimaryKey(PdfCodeTemporary record);", "int updateByPrimaryKey(SwipersDO record);", "int updateByPrimaryKey(PmPost record);", "int updateByPrimaryKey(SysNotice record);", "@Override\r\n\tpublic int updatePersionAccessPword(PersonAccessEntity entity) throws Exception {\n\t\treturn persionAccessDao.updatePword(entity);\r\n\t}", "int updateByPrimaryKey(BaseCountract record);", "int updateByPrimaryKey(CraftAdvReq record);", "int updateByPrimaryKey(TrainingCourse record);", "int updateByPrimaryKey(CodeBuildProcedure record);", "int updateByPrimaryKeyWithBLOBs(AnnouncementDO record);", "void update ( priorizedListObject v ) throws DAOException;", "int updateByPrimaryKey(Depart record);", "@Test\n public void update() {\n try{\n repo.save(s);\n repot.save(t);\n repon.save(n);\n Tema t2 = new Tema(1, 0, 6, \"GUI\");\n Student s2 = new Student(1,221, \"Pop Ion\",\"[email protected]\",\"prof\");\n Nota n2 = new Nota(1, 1, \"prof\", 10, \"Irelevant\");\n repo.save(s2);\n repot.save(t2);\n repon.save(n2);\n repo.update(s2);\n repot.update(t2);\n repon.update(n2);\n assert repo.findOne(1).getGrupa()==221;\n assert repot.findOne(1).getDeadline()==8;\n assert repon.findOne(\"11\").getFeedback()==\"Irelevant\";\n\n }\n catch (ValidationException e){\n }\n }", "@Override\n\tpublic void executeUpdateDinamicSQL(String s) throws Exception {\n\t\t\n\t}", "int updateByPrimaryKey(JzAct record);", "int updateByPrimaryKey(WdWordDict record);", "int updateByPrimaryKey(DashboardGoods record);", "int updateByPrimaryKey(Kaiwa record);", "int updateByPrimaryKeySelective(RepStuLearning record);", "int updateByPrimaryKeySelective(Tourst record);", "int updateByPrimaryKey(PrhFree record);", "int updateByPrimaryKey(Forumpost record);", "int updateByPrimaryKey(EtpBase record);", "@Update({\n \"update dept\",\n \"set dept_name = #{deptName,jdbcType=VARCHAR}\",\n \"where id = #{id,jdbcType=INTEGER}\"\n })\n int updateByPrimaryKey(Dept record);", "int updateByPrimaryKeySelective(Prueba record);", "int updateByPrimaryKey(organize_infoBean record);", "int updateByPrimaryKey(ClinicalData record);", "int updateByPrimaryKey(Access record);", "@Update({\n \"update soggetto_personale_scolastico\",\n \"set codice_fiscale = #{codiceFiscale,jdbcType=VARCHAR},\",\n \"id_asr = #{idAsr,jdbcType=BIGINT},\",\n \"cognome = #{cognome,jdbcType=VARCHAR},\",\n \"nome = #{nome,jdbcType=VARCHAR},\",\n \"data_nascita_str = #{dataNascitaStr,jdbcType=VARCHAR},\",\n \"comune_residenza_istat = #{comuneResidenzaIstat,jdbcType=VARCHAR},\",\n \"comune_domicilio_istat = #{comuneDomicilioIstat,jdbcType=VARCHAR},\",\n \"indirizzo_domicilio = #{indirizzoDomicilio,jdbcType=VARCHAR},\",\n \"telefono_recapito = #{telefonoRecapito,jdbcType=VARCHAR},\",\n \"data_nascita = #{dataNascita,jdbcType=DATE},\",\n \"asl_residenza = #{aslResidenza,jdbcType=VARCHAR},\",\n \"asl_domicilio = #{aslDomicilio,jdbcType=VARCHAR},\",\n \"email = #{email,jdbcType=VARCHAR},\",\n \"lat = #{lat,jdbcType=NUMERIC},\",\n \"lng = #{lng,jdbcType=NUMERIC},\",\n \"id_tipo_soggetto = #{idTipoSoggetto,jdbcType=INTEGER},\",\n \"utente_operazione = #{utenteOperazione,jdbcType=VARCHAR},\",\n \"data_creazione = #{dataCreazione,jdbcType=TIMESTAMP},\",\n \"data_modifica = #{dataModifica,jdbcType=TIMESTAMP},\",\n \"data_cancellazione = #{dataCancellazione,jdbcType=TIMESTAMP},\",\n \"id_soggetto_fk = #{idSoggettoFk,jdbcType=INTEGER},\",\n \"id_medico = #{idMedico,jdbcType=BIGINT}\",\n \"where id_soggetto = #{idSoggetto,jdbcType=BIGINT}\"\n })\n int updateByPrimaryKey(SoggettoPersonaleScolastico record);", "int updateByPrimaryKey(Disproduct record);", "int updateByPrimaryKey(IceApp record);", "int updateByPrimaryKey(SysAuthentication record);", "int updateByPrimaryKey(Online record);", "int updateByPrimaryKey(MemberTag record);", "int updateByPrimaryKey(UcOrderGuestInfo record);", "int updateByPrimaryKey(Pet record);", "int updateByPrimaryKey(SysCode record);", "int updateByPrimaryKey(ExamineApproveResult record);", "int updateByPrimaryKey(ExamRoom record);", "int updateByPrimaryKey(SPerms record);", "int updateByPrimaryKeySelective(countrylanguage record);", "int updateByPrimaryKey(PrescriptionVerifyRecordDetail record);", "int updateByPrimaryKeySelective(GoodsPo record);", "@Override\n\tpublic void executeUpdateDinamicQuery(String s) throws Exception {\n\t\t\n\t}", "int updateByPrimaryKey(Abum record);", "int updateByPrimaryKey(EcsAd record);", "int updateByPrimaryKey(NjProductTaticsRelation record);", "int updateByPrimaryKey(GirlInfo record);", "int updateByPrimaryKey(CptDataStore record);", "int updateByPrimaryKey(Engine record);", "int updateByPrimaryKey(PaasCustomAutomationRecord record);", "int updateByPrimaryKey(T00RolePost record);", "int updateByPrimaryKey(ProSchoolWare record);", "public TestNoun testnoun_search_for_update(long id, LuUser user) throws Exception {\n\t\t log.setLevel(Level.INFO);\n\t log.info(\"testnoun_search_for_update Dao started operation!\");\n\n\t\ttry{\n\n\t\t\tQuery result = entityManager.\n\t\t\tcreateNativeQuery(search_for_update_TestNoun,TestNoun.class)\n\n\t\t\t.setParameter(\"id\", id);;\n\n\t\t\tArrayList<TestNoun> TestNoun_list =\t(ArrayList<TestNoun>)result.getResultList();\n\n\t\t\tif(TestNoun_list == null){\n\n\t\t\tlog.error(\"testnoun_search_for_update Dao throws exception :\" + \"no TestNoun found\" );\n\t\t\t}\n\t\t\tlog.info(\"Object returned from testnoun_search_for_update Dao method !\");\n\t\t\treturn (TestNoun) TestNoun_list.get(0);\n\n\t\t}catch(Exception e){\n\n\t\t\t//new Exception(e.toString()); // this needs to be changed\n\t\t\tlog.error(\"testnoun_search_for_update Dao throws exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\t}", "public void update(ScahaDatabase _db) throws SQLException {\n\t\t// Lets update the person here.\r\n\t\t//\r\n\t\tsuper.update(_db);\r\n\t\t\r\n\t\t//\r\n\t\t// now.. we have to update the pertinat parts of the player table \r\n\t\t// to add the player extension data..\r\n\t\t\r\n\t\t// \r\n\t\t// is it an object that is not in the database yet..\r\n\t\t//\r\n\t\t//\r\n\t\tCallableStatement cs = _db.prepareCall(\"call scaha.updateManager(?,?,?,?)\");\r\n\t\t\r\n\t\t//LOGGER.info(\"HERE IS THE PERSON ID for manager:\" + super.ID);\r\n\t\t//LOGGER.info(\"HERE IS THE manager ID for manager:\" + this.ID);\r\n\t\t\r\n\t\tint i = 1;\r\n\t\tcs.registerOutParameter(1, java.sql.Types.INTEGER);\r\n\t\tcs.setInt(i++, this.ID);\r\n\t\tcs.setInt(i++, super.ID);\r\n\t\tcs.setInt(i++,1);\r\n\t\tcs.setString(i++,null);\r\n\t\tcs.execute();\r\n\t\t\t\t\r\n\t\t//\r\n\t\t// Update the new ID from the database...\r\n\t\t//\r\n\t\tthis.ID = cs.getInt(1);\r\n\t\tcs.close();\r\n\t\t//LOGGER.info(\"HERE IS THE New Manager ID:\" + this.ID);\r\n\t\t\r\n\t}", "int updateByPrimaryKey(Basicinfo record);", "public void crudOperationStudent(){\n //Retrieve Student\n Student student=entityManager.find(Student.class,2L);\n // persistence Context have Student\n //Retrieve Passport\n Passport passport=student.getPassport();\n // persistence Context have Student,passport\n //Update passport number for student\n passport.setPassportNo(\"ZX132322\");\n // persistence Context have Student, updated-passport\n //update Student details\n student.setAge(25);\n // persistence Context have updated-Student, updated-passport\n entityManager.persist(student);\n\n }", "int updateByPrimaryKey(ProEmployee record);", "int updateByPrimaryKey(Nutrition record);", "int updateByPrimaryKey(TrainCourse record);", "@Override\n\t\t\tpublic void onClick(View arg0) {\n\t\t\t\ttry\n\t\t\t\t{\n\n\t\t\t\t\t Class.forName(\"net.sourceforge.jtds.jdbc.Driver\");\n\t\t\t\t\t Connection con=DriverManager.getConnection(\"jdbc:jtds:sqlserver://192.168.1.7/DBVData;user=sa;password=123\"); //Server\n\t\t\t\t\t Statement stmt = con.createStatement();\n\t\t\t\t \n\t\t\t\t\t stmt.executeUpdate(\"Update EventNote set Status='\"+status+\"' where EventCode='\"+getcode+\"'\");\n\t\t\t\t\t // Toast.makeText(getBaseContext(),getcode,Toast.LENGTH_LONG).show();\n\t\t\t\t\t \n\t\t\t\t\t Toast.makeText(getBaseContext(),\"Updated Successfully\",Toast.LENGTH_LONG).show();\n finish();\t\t\t\t\n\t\t\t\t}\n\t\t\t\tcatch(Exception ex)\n\t\t\t\t{\n\t\t\t\t\tToast.makeText(getBaseContext(),ex.getMessage(), Toast.LENGTH_LONG).show();\n\t\t\t\t}\n\t\t\t}", "@Transactional\n\tpublic TestNoun create_testnoun(TestNoun TestNoun, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"create_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(create_TestNoun)\n\t\t\t.setParameter(\"testname\", TestNoun.getTestName())\n\t\t\t.setParameter(\"testage\", TestNoun.getTestAge())\n\t\t\t.setParameter(\"created_by\", user == null ? 0:user.getId())\n\t\t\t.setParameter(\"updated_by\", user == null ? 0:user.getId())\n;\n\n\t\t\tint insertedId = query.executeUpdate();\n\t\t\t\t\tString lastIndex=\"select last_insert_id()\";\n\t\t\t\t\tQuery sql = entityManager.createNativeQuery(lastIndex);\n\t\t\t\t\tBigInteger new_id = (BigInteger) sql.getSingleResult();\n\t\t\t\t\tTestNoun.setId(new_id.longValue());\n\t\t\t\t\tSystem.out.println(\"create data---\"+insertedId);\n\n\t\t\tlog.info(\"Object returned from create_testnoun Dao method !\");\n\n\t\t\treturn TestNoun;\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (create_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "private ServerError updateDatabase() {\n return updateDatabase(WebConf.DB_CONN, WebConf.JSON_OBJECTS, WebConf.DEFAULT_VERSION);\r\n }", "int updateByPrimaryKey(Notice record);", "@Override\r\n\tpublic void updateAd(EP par) {\n\t\tsession.update(par);//修改 \r\n\t\ttr.commit();//提交事务\r\n\t}", "int updateByPrimaryKey(AlipayInfo record);", "int updateByPrimaryKey(ReEducation record);" ]
[ "0.669791", "0.63268787", "0.61889744", "0.61300147", "0.60818404", "0.607838", "0.60654205", "0.60590804", "0.60332", "0.6031545", "0.60189337", "0.60052466", "0.5998296", "0.5976927", "0.5968224", "0.596713", "0.59554446", "0.59347206", "0.5900041", "0.58869123", "0.58821106", "0.5878582", "0.5851924", "0.58481395", "0.58352417", "0.5830241", "0.5811025", "0.5810873", "0.5806688", "0.58014977", "0.57982534", "0.5794567", "0.57941484", "0.5788703", "0.57833904", "0.5781883", "0.57815933", "0.5778879", "0.57787853", "0.57782483", "0.5776597", "0.5774634", "0.57667327", "0.5760113", "0.5756188", "0.57520616", "0.57441634", "0.5741311", "0.5737461", "0.5735312", "0.5733385", "0.5732701", "0.5724328", "0.57213944", "0.57192516", "0.5718958", "0.5716801", "0.57163906", "0.5715858", "0.57141155", "0.5712483", "0.5712106", "0.5711817", "0.5711338", "0.5707538", "0.5707365", "0.57072777", "0.570461", "0.5700777", "0.5696604", "0.5695679", "0.5691456", "0.56892836", "0.5681913", "0.5680785", "0.5678403", "0.5676049", "0.56750405", "0.5671321", "0.56684613", "0.5668284", "0.5667529", "0.56665707", "0.5666548", "0.5663498", "0.56632787", "0.56623644", "0.56611997", "0.565901", "0.56576693", "0.56563234", "0.56555945", "0.5653934", "0.5648388", "0.56476915", "0.5646307", "0.56453717", "0.5645213", "0.5644544", "0.56443924", "0.5643043" ]
0.0
-1
auths not ready at this time The purpose of Dao method is to perform delete operation of IPATestStage noun from database based on given noun id
@Transactional public String delete_ipateststage(long id, IPUser user) throws Exception { log.setLevel(Level.INFO); log.info("delete_ipateststage Dao started operation!"); try{ Query query = entityManager .createNativeQuery(delete_IPATestStage) .setParameter("id", id); query.executeUpdate(); log.info("Object returned from delete_ipateststage Dao method !"); return "{\"status\":\"success\"}"; }catch(Exception e){ //System.out.println("DAOException: " + e.toString()); log.error(" Dao method (delete_ipateststage) throws Exception : "+e.toString()); } return null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Transactional\n\tpublic String delete_testnoun(long id, LuUser user) throws Exception {\n\n\t \t log.setLevel(Level.INFO);\n\t log.info(\"delete_testnoun Dao started operation!\");//dhina updateverb\n\n\t\ttry{\n\t\t\tQuery query = entityManager\n\t\t\t\t\t.createNativeQuery(delete_TestNoun)\n\t\t\t.setParameter(\"id\", id);\n\n\t\t\tquery.executeUpdate();\n\n\t\t\tlog.info(\"Object returned from delete_testnoun Dao method !\");\n\n\t\t\treturn \"{\\\"status\\\":\\\"success\\\"}\";\n\n\t\t}catch(Exception e){\n\n\t\t\t//System.out.println(\"DAOException: \" + e.toString());\n\t\t\tlog.error(\" Dao method (delete_testnoun) throws Exception : \"+e.toString());\n\n\t\t}\n\t\treturn null;\n\n\n\n\t}", "public void delete(RutaPk pk) throws RutaDaoException;", "@Override\r\npublic int deleteByPrimaryKey(Integer possalesdetailid) {\n\treturn possalesdetail.deleteByPrimaryKey(possalesdetailid);\r\n}", "public void delete(int id) \n{ \n\ttvShowRepo.deleteById(id); \n}", "public void delete(NominaPuestoPk pk) throws NominaPuestoDaoException;", "int deleteByPrimaryKey(Integer actPrizeId);", "int deleteByPrimaryKey(Long articleTagId);", "int deleteByExample(LtsprojectpoExample example);", "void deletePokemon(Long pokemonId);", "int deleteByPrimaryKey(Long tagid);", "int deleteByPrimaryKey(Short act_id);", "public void deleteByVaiTroID(long vaiTroId);", "int deleteByPrimaryKey(String detailId);", "public void delete(RelacionConceptoEmbalajePk pk) throws RelacionConceptoEmbalajeDaoException;", "int deleteByPrimaryKey(String postId);", "int deleteByPrimaryKey(Integer petid);", "@Override\r\npublic int delete(int id) {\n\treturn detalle_pedidoDao.delete(id);\r\n}", "int deleteByPrimaryKey(String samId);", "public void delete(UsStatePk pk) throws UsStateDaoException;", "int deleteByPrimaryKey(String ponumberGoodsId);", "public void delete(DatiBancariPk pk) throws DatiBancariDaoException;", "int deleteByPrimaryKey(String noticeId);", "public void delete(TipologiaStrutturaPk pk) throws TipologiaStrutturaDaoException;", "int deleteByPrimaryKey(String licFlow);", "@Override\r\n\tpublic void delete(ConventionStage obj) {\n\t\ttry {\r\n\t\t\tStatement request = this.connect.createStatement();\r\n\t\t\trequest.executeUpdate(\"DELETE FROM \" + ConventionStageDAO.TABLE +\" WHERE NO_CONVENTION= \" +obj.getNumeroConvention());\r\n\t\t\trequest.close();\r\n\t\t} catch (SQLException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "int deleteByPrimaryKey(String objId);", "int deleteByPrimaryKey(String objId);", "@Delete({\n \"delete from test_module\",\n \"where id = #{id,jdbcType=VARCHAR}\"\n })\n int deleteByPrimaryKey(String id);", "int deleteByExample(SysIdExample example);", "int deleteByPrimaryKey(Integer announceid);", "@Query(value = \"{'dni._id' : ?0}\", delete = true)\r\n\tpublic void deleteByDni(String dni);", "int deleteByExample(InspectionAgencyExample example);", "int deleteByPrimaryKey(String fucno);", "void deleteAveria(Long idAveria) throws BusinessException;", "@Override\r\n\tpublic void delete(int idStrumento) {\n\t\tstrumentoRepository.delete(idStrumento);\r\n\t}", "int deleteByPrimaryKey(Integer postid);", "public void delete(LearningResultHasActivityPk pk) throws LearningResultHasActivityDaoException;", "int deleteByExample(ActivityHongbaoPrizeExample example);", "@Delete({\n \"delete from dept\",\n \"where id = #{id,jdbcType=INTEGER}\"\n })\n int deleteByPrimaryKey(Integer id);", "public void delete(TipoPk pk) throws TipoDaoException;", "@Override //删除id\n\tpublic void deletePoInfoById(String poinid) throws Exception {\n\t\tdao.delete(\"PoInfoMapper.deletePoInfoById\", poinid);\n\t}", "int deleteByExample(DiseaseExample example);", "int deleteByExample(AutoAssessDetailExample example);", "int deleteByPrimaryKey(Short adId);", "int deleteByPrimaryKey(Integer nutritionid);", "public void deleteOneWord(Pojo.OneWord e){ \n template.delete(e); \n}", "@Override\n\tpublic void deleteByOid(int oaId) {\n\t\tdesignMapper.deleteByOid(oaId);\n\t}", "int deleteByPrimaryKey(Long dictId);", "int deleteByExample(NjProductTaticsRelationExample example);", "void deleteDaftarhunianDtl(DaftarhunianDtl.MyCompositePK no) {\n }", "public void delete(SgfensBancoPk pk) throws SgfensBancoDaoException;", "int deleteByExample(UTbInvCategoryExample example);", "public void deleteOne(String id) {\n\t\t mongoTemplate.remove(new Query(Criteria.where(\"id\").is(id)), AsxDataVO.class); \r\n\t}", "@Override\r\n\tpublic void deleteAd(int tid) {\n\t\tQuery query = (Query) session.createQuery(\"delete EP where pid=:id\");\r\n\t\tquery.setParameter(\"id\", tid);\r\n\t\tquery.executeUpdate();//删除\r\n\t\ttr.commit();//提交事务\r\n\t}", "int deleteByPrimaryKey(String thingid);", "void delete(int entityId);", "int deleteByExample(DashboardGoodsExample example);", "int deleteByPrimaryKey(Integer typeiId);", "public void deleteByPrimaryKey(Long tagId) {\n }", "public void delete() {\r\n\t\tCampLeaseDAO leaseDao = (CampLeaseDAO) getApplicationContext().getBean(\"leaseDaoBean\", CampLeaseDAO.class);\r\n\t\tleaseDao.delete(this);\r\n\t}", "@Override\npublic void deleteById(String id) {\n\t\n}", "int deleteByExample(HuoDongExample example);", "void delete ( int id ) throws DAOException;", "int deleteByPrimaryKey(String maht);", "int deleteByPrimaryKey(String idTipoPersona) throws SQLException;", "int deleteByPrimaryKey(String depCode);", "int deleteByPrimaryKey(String goodsId);", "public void delete() {\n \t\t try(Connection con = DB.sql2o.open()) {\n \t\t\t String sql = \"DELETE FROM sightings where id=:id\";\n\t\t\t con.createQuery(sql)\n\t\t\t.addParameter(\"id\", this.id)\n\t\t\t.executeUpdate();\n\n \t\t }\n \t }", "int deleteByExample(TCpySpouseExample example);", "int deleteByPrimaryKey(String bid);", "int deleteByExample(BasicinfoCriteria example);", "int deleteByExample(ComplainNoteDOExample example);", "int deleteByPrimaryKey(Long catalogId);", "int deleteByExample(SysTeamExample example);", "int deleteByExample(JzActExample example);", "int deleteByPrimaryKey(Long dduId);", "int deleteByExample(Assist_tableExample example);", "int deleteByExample(ProcurementSourceExample example);", "public abstract boolean delete(PK id);", "@Override\n public void delete(String id) {\n log.debug(\"Request to delete Aluno : {}\", id);\n alunoRepository.delete(id);\n alunoSearchRepository.delete(id);\n }", "int deleteByPrimaryKey(Integer tfId);", "void deleteBypostno(int postno);", "int deleteByExample(BasicInfoPrecursorProcessTypeExample example);", "int deleteByExample(PmKeyDbObjExample example);", "int deleteByPrimaryKey(String ugId);", "int deleteByPrimaryKey(countrylanguageKey key);", "int deleteByPrimaryKey(String deptCode);", "int deleteByPrimaryKey(GpPubgPlayer record);", "int deleteByExample(AdminExample example);", "public void deleteFromPoseOrder() { \n \ttry {\n\t\t\tthis.openDataBase();\n\t\t\tmyDataBase.execSQL(DeletePoses);\n\t\t\tthis.close();\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\tLog.d(\"SQL Exception\", e.toString());\n\t\t}\n \t\n }", "int deleteByPrimaryKey(String taxregcode);", "int deleteByExample(ArticleDoExample example);", "public void Delete(){\n String whereClause2 = PostDatabase.ID + \" = ?\";\n // Specify arguments in placeholder order.\n String[] whereArgs2 = { \"6\" };\n // Issue SQL statement.\n sqlDB.delete(PostDatabase.TABLE_POSTS, whereClause2, whereArgs2);\n\n }", "public String deleterPetDetails(int petId);", "int deleteByExample(organize_infoBeanExample example);", "int deleteByPrimaryKey(Integer zid);", "int deleteByExample(SurveystatusPkeyExample example);", "int deleteByExample(DepartExample example);", "int deleteByPrimaryKey(Integer idMovCta);", "int deleteByPrimaryKey(Integer pkid);", "int deleteByPrimaryKey(Integer pkid);" ]
[ "0.6920704", "0.6780835", "0.67604625", "0.6670626", "0.65905064", "0.65822107", "0.6518991", "0.6517877", "0.65175813", "0.6509112", "0.6497942", "0.6495199", "0.6478352", "0.64778626", "0.64650023", "0.64510113", "0.64486206", "0.6445678", "0.6428311", "0.64270395", "0.64230424", "0.64161396", "0.6407722", "0.6404763", "0.63982", "0.6383803", "0.6383803", "0.63774717", "0.63654757", "0.6346164", "0.63396215", "0.63307816", "0.6327637", "0.6324643", "0.632167", "0.63118774", "0.63058645", "0.6284982", "0.62835926", "0.62754434", "0.62747854", "0.62618625", "0.6261773", "0.62608385", "0.6244939", "0.624242", "0.6229089", "0.62199336", "0.62164897", "0.62162894", "0.6215968", "0.62052464", "0.62050295", "0.6202146", "0.6201852", "0.6197999", "0.61955935", "0.6192675", "0.61908937", "0.6189785", "0.6186054", "0.618481", "0.6183221", "0.6178492", "0.6178477", "0.6177724", "0.6168338", "0.61638975", "0.6162132", "0.6156974", "0.6154818", "0.6154239", "0.61506987", "0.6150047", "0.6146112", "0.61316913", "0.61314464", "0.6130349", "0.61279035", "0.6124691", "0.6115834", "0.6113772", "0.6113116", "0.6112583", "0.6109902", "0.6108156", "0.61027867", "0.6101487", "0.60996366", "0.60965854", "0.60962754", "0.60862905", "0.6085582", "0.60838944", "0.60824585", "0.6080639", "0.6080551", "0.60783595", "0.60781276", "0.60730034", "0.60730034" ]
0.0
-1
Creates the currency unit for the given currency code. See the for more information, including a table of currency codes. The currency code is added to the standard (UCUM) symbol map.
public Currency(String code) { _code = code; UnitFormatImpl.getInstance().getSymbolMap().label(this, code); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Currency(String code) {\n _toBaseUnit = new Converter(code, false);\n UnitFormat.getInstance().label(this, code);\n }", "Uom getCurrencyUom();", "public void buy(String code, Integer units) throws InsufficientUnitsException, InvalidCodeException {\n\t\tAtomicInteger count = new AtomicInteger();\n\t\tcentsMap.forEach((k,v)-> {\n\t\t\tif(k.equalsIgnoreCase(code)) {\n\t\t\t\tSystem.out.println(\"Code : \" + k + \" Value : \" + v);\t\t\t\t\n\t\t\t\tstockMap.forEach((key,value)-> {\n\t\t\t\t\t\tSystem.out.println(\"Code : \" + key + \" Value : \" + value);\n\t\t\t\t\t\tif(value > 0 && count.intValue() == 0) {\n\t\t\t\t\t\t\tstockMap.put(key, value - units);\n\t\t\t\t\t\t\tcount.incrementAndGet();\n\t\t\t\t\t\t}\n\t\t\t\t});\t\t\t\t\n\t\t\t\t// track the value \n\t\t\t\ttradePerCentsList.add(v);\n\t\t\t}\t\t\t\n\t\t});\n\n\t}", "@Override\r\n\tpublic Currency fromString(String code) {\n\t\tCurrency currency = null;\r\n\t\t\r\n\t\tswitch(code.toUpperCase()) {\r\n\t\t\tcase \"EUR\": currency = new Currency(code, \"Euro\"); break;\r\n\t\t\tcase \"USD\": currency = new Currency(code, \"US Dollar\"); break;\r\n\t\t\tcase \"INR\": currency = new Currency(code, \"Rupees\"); break;\r\n\t\t}\r\n\t\t\r\n\t\treturn currency;\r\n\t}", "public void sell(String code, Integer units) throws InvalidCodeException {\n\t\tAtomicInteger count = new AtomicInteger();\n\t\tcentsMap.forEach((k,v)-> {\n\t\t\tif(k.equalsIgnoreCase(code)) {\n\t\t\t\tSystem.out.println(\"Code : \" + k + \" Value : \" + v);\t\t\t\t\n\t\t\t\tstockMap.forEach((key,value)-> {\n\t\t\t\t\t\tSystem.out.println(\"Code : \" + key + \" Value : \" + value);\n\t\t\t\t\t\tif(value > 0 && count.intValue() == 0) {\n\t\t\t\t\t\t\tstockMap.put(key, value + units);\n\t\t\t\t\t\t\tcount.incrementAndGet();\n\t\t\t\t\t\t}\n\t\t\t\t});\t\t\t\t\n\t\t\t\t// track the value \n\t\t\t\ttradePerCentsList.add(v);\n\t\t\t}\t\t\t\n\t\t});\n\t\t\n\t}", "public final EObject ruleUnitConstructionOperator() throws RecognitionException {\n EObject current = null;\n\n EObject lv_unit_2_0 = null;\n\n\n EObject temp=null; setCurrentLookahead(); resetLookahead(); \n \n try {\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:5992:6: ( ( '$' '(' ( (lv_unit_2_0= ruleUnitExpression ) ) ')' ) )\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:5993:1: ( '$' '(' ( (lv_unit_2_0= ruleUnitExpression ) ) ')' )\n {\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:5993:1: ( '$' '(' ( (lv_unit_2_0= ruleUnitExpression ) ) ')' )\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:5993:3: '$' '(' ( (lv_unit_2_0= ruleUnitExpression ) ) ')'\n {\n match(input,55,FOLLOW_55_in_ruleUnitConstructionOperator10420); \n\n createLeafNode(grammarAccess.getUnitConstructionOperatorAccess().getDollarSignKeyword_0(), null); \n \n match(input,25,FOLLOW_25_in_ruleUnitConstructionOperator10430); \n\n createLeafNode(grammarAccess.getUnitConstructionOperatorAccess().getLeftParenthesisKeyword_1(), null); \n \n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:6001:1: ( (lv_unit_2_0= ruleUnitExpression ) )\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:6002:1: (lv_unit_2_0= ruleUnitExpression )\n {\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:6002:1: (lv_unit_2_0= ruleUnitExpression )\n // ../org.eclipselabs.mscript.language/src-gen/org/eclipselabs/mscript/language/parser/antlr/internal/InternalMscript.g:6003:3: lv_unit_2_0= ruleUnitExpression\n {\n \n \t currentNode=createCompositeNode(grammarAccess.getUnitConstructionOperatorAccess().getUnitUnitExpressionParserRuleCall_2_0(), currentNode); \n \t \n pushFollow(FOLLOW_ruleUnitExpression_in_ruleUnitConstructionOperator10451);\n lv_unit_2_0=ruleUnitExpression();\n _fsp--;\n\n\n \t if (current==null) {\n \t current = factory.create(grammarAccess.getUnitConstructionOperatorRule().getType().getClassifier());\n \t associateNodeWithAstElement(currentNode.getParent(), current);\n \t }\n \t try {\n \t \t\tset(\n \t \t\t\tcurrent, \n \t \t\t\t\"unit\",\n \t \t\tlv_unit_2_0, \n \t \t\t\"UnitExpression\", \n \t \t\tcurrentNode);\n \t } catch (ValueConverterException vce) {\n \t\t\t\thandleValueConverterException(vce);\n \t }\n \t currentNode = currentNode.getParent();\n \t \n\n }\n\n\n }\n\n match(input,26,FOLLOW_26_in_ruleUnitConstructionOperator10461); \n\n createLeafNode(grammarAccess.getUnitConstructionOperatorAccess().getRightParenthesisKeyword_3(), null); \n \n\n }\n\n\n }\n\n resetLookahead(); \n \tlastConsumedNode = currentNode;\n \n }\n \n catch (RecognitionException re) { \n recover(input,re); \n appendSkippedTokens();\n } \n finally {\n }\n return current;\n }", "com.google.protobuf.StringValue getCurrencyCode();", "public String getUnit() {\n\t\treturn(symbol);\n\t}", "public abstract Quantity<Q> create(Number value, Unit<Q> unit);", "private View createCurrency() {\r\n\t\tTextView t = new TextView(getContext());\r\n\t\tLayoutParams blp = new LayoutParams(android.view.ViewGroup.LayoutParams.WRAP_CONTENT,\r\n\t\t\t\tandroid.view.ViewGroup.LayoutParams.WRAP_CONTENT);\r\n\t\tblp.leftMargin = 5;\r\n\t\tt.setLayoutParams(blp);\r\n\r\n\t\tif (account.getCurrency().length() > 3) {\r\n\t\t\tt.setText(account.getCurrency().substring(3));\r\n\t\t} else {\r\n\t\t\tt.setText(account.getCurrency());\r\n\t\t}\r\n\t\tt.setTextSize(16);\r\n\t\tTypeface font = CurrencyUtil.currencyFace;\r\n\t\tt.setTypeface(font);\r\n\t\tif (account.getBalance() < 0) {\r\n\t\t\tt.setTextColor(getContext().getResources().getColor(R.color.negative));\r\n\t\t} else {\r\n\t\t\tt.setTextColor(getContext().getResources().getColor(R.color.positive));\r\n\t\t}\r\n\t\treturn t;\r\n\t}", "public Price currencyCode(String currencyCode) {\n this.currencyCode = currencyCode;\n return this;\n }", "public UnitP(UnitP unitP) \n {\n Value = unitP.Value;\n BaseTenExponent = unitP.BaseTenExponent;\n Unit = unitP.Unit;\n UnitType = unitP.UnitType;\n UnitSystem = unitP.UnitSystem;\n UnitPrefix = new Prefix(unitP.UnitPrefix);\n UnitParts = new ArrayList<UnitPart>(unitP.UnitParts);\n UnitString = unitP.UnitString;\n OriginalUnitString = unitP.OriginalUnitString;\n ValueAndUnitString = unitP.ValueAndUnitString;\n Error = new ErrorInfo(unitP.Error);\n }", "@Test\n public void desiredCurNumberConversionUSD(){\n //standard set up\n CurrencyRates one = new CurrencyRates();\n //checks if 2 corresponds to USD\n assertEquals(\"USD\", one.desiredCurNumberConversion(2));\n }", "public String getUnitPrice() {\n\t\tPrice discountP=null;\n\t\tdouble disAmount=this.price.getBasePrice();\n\t\tPrice p=new Price(this.price.getBasePrice());\n\t\tif(this.getDiscount()!=null){\n\t\t\tif(this.getDiscount().getSkuLimit() > 0 && !this.price.getBasePriceUnit().equalsIgnoreCase(\"lb\") && this.getDiscount().getSkuLimit() != this.getQuantity()) {\n\t\t\t\t\n\t\t\t\tdisAmount=this.price.getBasePrice();\n\t\t\t\t\n\t\t\t//APPDEV-4148-Displaying unit price if quantity is greater than sku limit - START\n\t\t\t\t\n\t\t\t\tif(this.getDiscount().getSkuLimit() < this.getQuantity()){\n\t\t\t\t\tif(this.getDiscount().getDiscountType().equals(EnumDiscountType.PERCENT_OFF))\n\t\t\t\t\t{\t\t\t\t\t\t\t\t\t\t\t\n\t\t\t\t\t\tdisAmount=((this.price.getBasePrice() * this.getQuantity()) - ((this.price.getBasePrice() * this.getDiscount().getSkuLimit()) * this.getDiscount().getAmount() )) / this.getQuantity();\n\t\t\t\t\t}\n\t\t\t\t\telse\n\t\t\t\t\t{\n\t\t\t\t\t\tdisAmount=((this.price.getBasePrice() * (this.getQuantity())) - (this.getDiscount().getAmount() * this.getDiscount().getSkuLimit()))/ this.getQuantity() ;\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\t\n\t\t\t//APPDEV-4148-Displaying unit price if quantity is greater than sku limit - END\n\t\t\t\t\n\t\t\t} else if(this.getDiscount().getSkuLimit() > 0 && this.price.getBasePriceUnit().equalsIgnoreCase(\"lb\") && this.getDiscount().getDiscountType().equals(EnumDiscountType.DOLLAR_OFF)) {\n\t\t\t\tdisAmount=this.price.getBasePrice();\n\t\t\t} else {\n\t\t\t\tif(this.getDiscount().getMaxPercentageDiscount() > 0) {\n\t\t\t\t\tdisAmount = this.orderLine.getPrice()/this.orderLine.getQuantity();\n\t\t\t\t} else {\n\t\t\t\t\ttry {\n\t\t\t\t\t\tdiscountP=PricingEngine.applyDiscount(p,1,this.getDiscount(),this.price.getBasePriceUnit());\n\t\t\t\t\t\tdisAmount=discountP.getBasePrice();\n\t\t\t\t\t} catch (PricingException e) {\n\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t//Apply the coupon discount on top of line item discount and calculate the final base price.\n\t\tif (this.getCouponDiscount() != null) {\n\t\t\ttry {\n\t\t\t\tdiscountP = PricingEngine.applyCouponDiscount(null!=discountP?discountP:p, 1/this.getQuantity(), this.getCouponDiscount(), this.price.getBasePriceUnit());\n\t\t\t\tdisAmount = discountP.getBasePrice();\n\t\t\t} catch (PricingException e) {\n\t\t\t\tdisAmount = 0.0;\n\t\t\t}\n\t\t} \n\t\t\t \n\t\treturn CURRENCY_FORMATTER.format(disAmount) + \"/\" + this.price.getBasePriceUnit().toLowerCase();\n\t}", "@Override\r\n\tpublic Map<Character, Double> SetUnitPrice() {\r\n\t\tPricePerUnit.put('A', 1.25);\r\n\t\tPricePerUnit.put('B', 4.25);\r\n\t\tPricePerUnit.put('C', 1.00);\r\n\t\tPricePerUnit.put('D', 0.75);\r\n\t\treturn PricePerUnit;\r\n\t}", "public abstract double toBasicUnit(double unit);", "public LNDCDC_NCS_NCSAR_NCSAR_BUSINESS_UNITS() {}", "public Saving currencyCode(String currencyCode) {\n this.currencyCode = currencyCode;\n return this;\n }", "public void setCurrencyCode(String currencyCode) {\n this.currencyCode = currencyCode;\n }", "public Units getUnitTable();", "public Builder setUnit(final Unit value) {\n _unit = value;\n return this;\n }", "public void setUnitCd(String unitCd) {\n this.unitCd = unitCd;\n }", "Unit(Apfloat unitIn, UnitType utIn) {\n\t\tthis(unitIn, utIn, 1);\n\t}", "public Unit(String unitName, String symbol, String description) {\n this.name = unitName;\n this.symbol = symbol;\n this.description = description;\n }", "public void setCurrencyCode(String currencyCode)\r\n {\r\n m_currencyCode = currencyCode;\r\n }", "public UnitP\n (\n UnitP unitP, ErrorTypes errorType, ExceptionHandlingTypes exceptionHandling\n )\n {\n if (unitP == null) unitP = new UnitP();\n\n UnitPConstructor unitP2 = new UnitPConstructor\n (\n unitP.OriginalUnitString, ExceptionInstantiation.NewUnitInfo(unitP),\n UnitTypes.None, UnitSystems.None, errorType,\n (\n exceptionHandling != ExceptionHandlingTypes.NeverTriggerException ?\n exceptionHandling : unitP.Error.ExceptionHandling\n )\n );\n\n if (unitP2.ErrorType != ErrorTypes.None)\n {\n Value = 0.0;\n BaseTenExponent = 0;\n UnitPrefix = new Prefix(unitP2.UnitInfo.Prefix.getPrefixUsage());\n UnitParts = new ArrayList<UnitPart>();\n Unit = Units.None;\n UnitType = UnitTypes.None;\n UnitSystem = UnitSystems.None;\n OriginalUnitString = \"\";\n ValueAndUnitString = \"\";\n UnitString = \"\";\n }\n else\n {\n OriginalUnitString = unitP2.OriginalUnitString;\n Value = unitP2.Value;\n BaseTenExponent = unitP2.UnitInfo.BaseTenExponent;\n Unit = unitP2.UnitInfo.Unit;\n UnitType = unitP2.UnitType;\n UnitSystem = unitP2.UnitSystem;\n UnitPrefix = new Prefix(unitP2.UnitInfo.Prefix);\n UnitParts = unitP2.UnitInfo.Parts;\n UnitString = unitP2.UnitString;\n ValueAndUnitString = unitP2.ValueAndUnitString;\n }\n\n //If applicable, this instantiation would trigger an exception right away.\n Error = ExceptionInstantiation.NewErrorInfo\n (\n \tunitP2.ErrorType, unitP2.ExceptionHandling\n );\n }", "public Currency findCurrencyByCode(String currency);", "public void setUnit (String value) {\n\tthis.unit = value;\n }", "public String getKcUnit() {\n return kcUnit;\n }", "public String getUnitCd() {\n return unitCd;\n }", "Uom getOrigCurrencyUom();", "public Unit giveMeUnit(UnitDef unitDef, AIFloat3 pos);", "public void setUnitTable(Units value);", "public void setUnit(String unit);", "public String getCode() {\n return _toBaseUnit._code;\n }", "public void setKcUnit(String kcUnit) {\n this.kcUnit = kcUnit;\n }", "public Units(String unitName, int credits) {\n this.unitName = unitName;\n this.credits = credits;\n }", "public Unit10(String name)\n {\n \n this.name = name;\n \n \n }", "public VoucherSummary(CurrencyUnit currencyUnit) {\n this.currencyCode = currencyUnit;\n\t\tresetValues();\n\t}", "Unit(String unitIn, UnitType utIn) {\n\t\tthis(new Apfloat(unitIn, APFLOATPRECISION), utIn, 1);\n\t}", "public Integer CreateUnit(Unit U) {\n\t\tif (UnitContainer.size() == 0) {\n\t\t\tif ((TileID !=4)&(TileID != 3)){\n\t\t\t\tUnitContainer.add(U);\n\t\t\t\tU.MoveLeft = 0.0;\n\t\t\t\tU.locate(xloc, yloc);\n\t\t\t\treturn 1; //Placement success\n\t\t\t} else {\n\t\t\t\treturn 0; //Tile is mountains or water\n\t\t\t}\n\t\t} else {\n\t\t\treturn 0; //Already a unit here\n\t\t}\n\t}", "public PurchaseType(java.lang.String code)\r\n {\r\n super(code);\r\n }", "public UnitP(String valueAndUnit, ExceptionHandlingTypes exceptionHandling, PrefixUsageTypes prefixUsage)\n {\n ErrorTypes parsingError = \n (\n valueAndUnit == null ? ErrorTypes.NumericParsingError : ErrorTypes.None\n );\n\n UnitInfo unitInfo = ExceptionInstantiation.NewUnitInfo(0.0, exceptionHandling, prefixUsage);\n \n String unitString = \"\";\n\n if (parsingError == ErrorTypes.None)\n {\n UnitInfo tempInfo = MethodsUnitP.ParseValueAndUnit(valueAndUnit);\n \n if (tempInfo.Error.Type == ErrorTypes.None)\n {\n unitString = tempInfo.TempString;\n unitInfo.Value = tempInfo.Value;\n unitInfo.BaseTenExponent = tempInfo.BaseTenExponent;\n }\n else parsingError = tempInfo.Error.Type;\n }\n\n if (parsingError != ErrorTypes.None && !valueAndUnit.contains(\" \"))\n {\n //valueAndUnit is assumed to only contain unit information.\n parsingError = ErrorTypes.None;\n unitInfo.Value = 1.0;\n unitString = valueAndUnit;\n }\n\n UnitPConstructor unitP2 = MethodsUnitP.GetUnitP2(unitInfo, unitString);\n\n OriginalUnitString = unitP2.OriginalUnitString;\n Value = unitP2.Value;\n BaseTenExponent = unitP2.UnitInfo.BaseTenExponent;\n Unit = unitP2.UnitInfo.Unit;\n UnitType = unitP2.UnitType;\n UnitSystem = unitP2.UnitSystem;\n UnitPrefix = new Prefix(unitP2.UnitInfo.Prefix.getFactor(), prefixUsage);\n UnitParts = unitP2.UnitInfo.Parts;\n UnitString = unitP2.UnitString;\n ValueAndUnitString = unitP2.ValueAndUnitString;\n //If applicable, this instantiation would trigger an exception right away.\n Error = ExceptionInstantiation.NewErrorInfo\n (\n (parsingError != ErrorTypes.None ? parsingError : unitP2.ErrorType),\n unitP2.ExceptionHandling\n );\n }", "public UnitsComponent() {\n\t\ttry {\n\t\t\tsetHardwareUnitString(\"\");\n\t\t\tsetUserUnits(\"\");\n\t\t} catch (DeviceException e) {\n\t\t\tlogger.error(\"Code logic error:\", e);\n\t\t}\n\t\tuserUnitHasBeenExplicitlySet = false;\n\t\thardwareUnitHasBeenExplicitlySet = false;\n\t}", "public void setUnit(String unit) {\n this.unit = unit;\n }", "public void setUnitPrice(MMDecimal unitPrice) {\r\n this.unitPrice = unitPrice;\r\n }", "@Test\n public void testSetCurrency() {\n CurrencyUnit cu = Waehrung.of(\"XXX\");\n factory.setCurrency(cu);\n Geldbetrag geldbetrag = factory.create();\n assertEquals(cu, geldbetrag.getCurrency());\n }", "public Unit(float length, float width, float height, float totalCost, String unitKind, Furniture furniture, Electrictiy electrictiy, Wall wall, Roof roof, Floor floor, Plumbing plumbing) {\n this.length = length;\n this.width = width;\n this.height = height;\n this.totalCost = totalCost;\n this.unitKind = unitKind;\n this.furniture = furniture;\n this.electrictiy = electrictiy;\n this.wall = wall;\n this.roof = roof;\n this.floor = floor;\n this.plumbing = plumbing;\n }", "public void setUnitcd(String unitcd) {\r\n this.unitcd = unitcd;\r\n }", "Unit(String unitIn, UnitType utIn, int expIn) {\n\t\tthis(new Apfloat(unitIn, APFLOATPRECISION), utIn, expIn);\n\t}", "@Override\n\tpublic String getCurrencyCode() {\n\t\treturn null;\n\t}", "private String getResultUnit() {\n switch (mCalculationType) {\n case CONSUMPTION_L_100_KM:\n return \"l/100 km\";\n case CONSUMPTION_KM_L:\n return \"km/l\";\n case CONSUMPTION_MPG:\n return \"mpg\";\n default:\n return \"\";\n }\n }", "public Units(int unitID, String unitName, int credits) {\n this.unitName = unitName;\n this.credits = credits;\n this.unitID = unitID;\n }", "Unit(Apfloat unitIn, UnitType utIn, int expIn) {\n\t\tunitValue = unitIn;\n\t\tunitType = utIn;\n\t\texponent = expIn;\n\t}", "public String getKcUnitName() {\n return kcUnitName;\n }", "public Data(\n final String name,\n final String code,\n final int numericCode,\n final String symbol,\n final String fractionSymbol,\n final int fractionsPerUnit,\n final Rounding rounding,\n final String formatString,\n final Currency triangulationCurrency\n ) {\n this.name = (name);\n this.code = (code);\n this.numeric = (numericCode);\n this.symbol = (symbol);\n this.fractionSymbol = (fractionSymbol);\n this.fractionsPerUnit = (fractionsPerUnit);\n this.rounding = (rounding);\n this.triangulated = (triangulationCurrency);\n this.formatString = (formatString);\n }", "public void setUnit(String unit)\n {\n this.unit = unit;\n }", "public void unitCreate(int unitID) {\n\t\tUnit u = bwapi.getUnit(unitID);\n\t\tUnitType type = bwapi.getUnitType(u.getTypeID());\n\t\tbwapi.printText(type.getName() + \" has been created.\");\n\t\t\n\t\tif (type.isWorker()) {\n\t\t\tbwapi.printText(\"Assigning worker to ResourceManager\");\n\t\t\tassignUnit(bwapi.getUnit(unitID), ResourceManager.class.getSimpleName());\n\t\t}\n\t\telse if (type.isAttackCapable() || type.isSpellcaster()) {\n\t\t\tbwapi.printText(\"Assigning attacking unit to ArmyManager\");\n\t\t\tassignUnit(bwapi.getUnit(unitID), ArmyManager.class.getSimpleName());\n\t\t}\n\t\telse if (type.isBuilding()) {\n\t\t\tint builderId = bwapi.getUnit(BuildManager.getInstance().getNearestUnit(UnitTypes.Protoss_Probe.ordinal(), u.getX(), u.getY())).getID();\n\t\t\t\n\t\t\tbwapi.printText(\"Assigning building to BuildingManager\");\n\t\t\tassignUnit(bwapi.getUnit(unitID), BuildManager.class.getSimpleName());\n\t\t\t\n\t\t\t//reassigns worker from resource mgr -> scout mgr if first pylon built\n\t\t\tif (u.getTypeID() == UnitTypes.Protoss_Pylon.ordinal() && BuildManager.getInstance().getBuildingCount(UnitTypes.Protoss_Pylon.ordinal()) == 1) {\n\t\t\t\tbwapi.printText(\"Assigning scout to ScoutManager\");\n\t\t\t\tif (!alreadyGaveScout) {\n\t\t\t\t\talreadyGaveScout = true;\n\t\t\t\t\trequestScout(builderId);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}", "public Unit(String symbol) throws ParseException {\n\t\tthis.set(symbol) ;\n\t}", "private void changeUnitWithDirection() {\n MainActivity app = MainActivity.app;\n if (app == null) return;\n int unit = SharedPreferencesManager.getCurrencyUnit(app);\n switch (unit) {\n case BRConstants.CURRENT_UNIT_BITS:\n SharedPreferencesManager.putCurrencyUnit(app, BRConstants.CURRENT_UNIT_MBITS);\n break;\n case BRConstants.CURRENT_UNIT_MBITS:\n SharedPreferencesManager.putCurrencyUnit(app, BRConstants.CURRENT_UNIT_BITCOINS);\n break;\n case BRConstants.CURRENT_UNIT_BITCOINS:\n SharedPreferencesManager.putCurrencyUnit(app, BRConstants.CURRENT_UNIT_BITS);\n break;\n }\n\n }", "private String getAmountUnit(int unit) {\n switch (unit) {\n case UNIT_LITERS:\n return getResourceString(R.string.val_l);\n case UNIT_GALLONS:\n return getResourceString(R.string.val_g);\n }\n\n return \"\";\n }", "public Pokemon.Currency.Builder getCurrencyBuilder() {\n bitField0_ |= 0x00000400;\n onChanged();\n return getCurrencyFieldBuilder().getBuilder();\n }", "String getUnit();", "@SkipValidation\n public String setUpCurrency() {\n if ((currency != null) && (currency.getHcmoCurrencyId() != null)) {\n currency = currencyService.getCurrency(currency.getHcmoCurrencyId());\n }\n return SUCCESS;\n }", "public String getUnit() {\n String unit = (String) comboUnits.getSelectedItem();\n if (\"inch\".equals(unit)) {\n return \"in\";\n } else if (\"cm\".equals(unit)) {\n return \"cm\";\n } else if (\"mm\".equals(unit)) {\n return \"mm\";\n } else if (\"pixel\".equals(unit)) {\n return \"px\";\n }\n return \"\";\n }", "public static String convertToRawCasesAccounting(long units, int UnitsPerSKU) {\n\n\t\t boolean IsNegative=false;\n\t\t if(units<0) {\n\t\t\t units = units*-1;\n\t\t\t IsNegative = true;\n\t\t }\n\t\t \n\t\t String ret = \"\";\n\t\t if (UnitsPerSKU != 0) {\n\t\t\t double RawCasesDouble = (double) units / (double) UnitsPerSKU;\n\t\t\t String RawCasesString = RawCasesDouble + \"\";\n\t\t\t if (RawCasesString.indexOf(\".\") != -1) {\n\t\t\t\t RawCasesString = RawCasesString.substring(0,\n\t\t\t\t\t\t RawCasesString.indexOf(\".\"));\n\t\t\t }\n\t\t\t long RawCases = Utilities.parseLong(RawCasesString);\n\n\t\t\t long RawCasesUnits = RawCases * UnitsPerSKU;\n\n\t\t\t long bottles = units - RawCasesUnits;\n\n\t\t\t if (bottles == 0) {\n\t\t\t\t ret = getDisplayCurrencyFormat(RawCases) + \"\";\n\t\t\t } else {\n\t\t\t\t ret = getDisplayCurrencyFormat(RawCases) + \"~\" + bottles;\n\t\t\t }\n\t\t }\n\t\t \n\t\t if(IsNegative){\n\t\t\t ret = \"(\"+ret+\")\";\n\t\t }\n\t\t \treturn ret;\n\t\t }", "public UnitP\n (\n Object numberX, String unitString, \n ExceptionHandlingTypes exceptionHandling,\n PrefixUsageTypes prefixUsage\n )\n {\n \t\n UnitPConstructor unitP2 = MethodsUnitP.GetUnitP2\n (\n \tOtherPartsNumberParserMethods.GetUnitInfoFromNumberX(numberX, exceptionHandling, prefixUsage), unitString\n );\n\n Value = unitP2.Value;\n BaseTenExponent = unitP2.UnitInfo.BaseTenExponent;\n Unit = unitP2.UnitInfo.Unit;\n UnitType = unitP2.UnitType;\n UnitSystem = unitP2.UnitSystem;\n UnitPrefix = new Prefix(unitP2.UnitInfo.Prefix);\n UnitParts = new ArrayList<UnitPart>(unitP2.UnitInfo.Parts);\n UnitString = unitP2.UnitString;\n ValueAndUnitString = unitP2.ValueAndUnitString;\n OriginalUnitString = \"\";\n //If applicable, this instantiation would trigger an exception right away.\n Error = ExceptionInstantiation.NewErrorInfo(unitP2.ErrorType, unitP2.ExceptionHandling);\n }", "@Override\n\tpublic String gen_citation_unit(String name, Vector<String> lambda_terms) {\n\t\treturn name;\n\t}", "@Test\n public void testConstantPricePerUnit() throws Exception {\n {\n Product beans = new Product(\n \"Can of Beans\",\n \"SKU-0001\",\n ToMoney.from(Multiply.by(65)));\n\n assertEquals(new Money(0*65),beans.getPrice(0));\n assertEquals(new Money(1*65),beans.getPrice(1));\n assertEquals(new Money(2*65),beans.getPrice(2));\n assertEquals(new Money(3*65),beans.getPrice(3));\n }\n // or, using the speical constructor:\n {\n Product beans = new Product(\n \"Can of Beans\",\n \"SKU-0001\",\n 65);\n\n assertEquals(new Money(0*65),beans.getPrice(0));\n assertEquals(new Money(1*65),beans.getPrice(1));\n assertEquals(new Money(2*65),beans.getPrice(2));\n assertEquals(new Money(3*65),beans.getPrice(3));\n }\n }", "private void addCurrency() {\r\n\t\tString currencyCode = signalThreeLetters();\r\n\t\tif (currencyCode == null){\r\n\t\t\treturn;\r\n\t\t}\r\n System.out.print(\"Enter the exchange rate (value of 1 \" +currencyCode+ \" in NZD): \");\r\n String exchangeRateStr = keyboardInput.getLine();\r\n \r\n double exchangeRate = Double.parseDouble(exchangeRateStr);\r\n if (exchangeRate <= 0) {\r\n \tSystem.out.println(\"Negative exchange rates not permitted. Returning to menu.\");\r\n \tSystem.out.println();\r\n \treturn;\r\n }\r\n System.out.println();\r\n if (currencies == null) {\r\n \tcurrencies = new Currencies();\r\n }\r\n currencies.addCurrency(currencyCode, exchangeRate);\r\n System.out.println(\"Currency \" +currencyCode+ \" with exchange rate \" + exchangeRate + \" added\");\r\n System.out.println();\r\n\t}", "public String getCurrencyCode() {\n return currencyCode;\n }", "public double convert(double amount, Unit u);", "public String getCanonicalUnitPrice()\n {\n String retName = null;\n\n // Expecting the linked list to be sorted\n for(Unit unit : measurementUnits)\n if(unit.getValue() <= size)\n retName = size + \" \" + unit.getName() + \" per \" + price.getValue() + \" satoshi\";\n else\n break;\n\n return retName;\n }", "private static Map<String, Double> createCurrencyPairRates() {\n\t\t\n\t\tMap<String, Double> currencyRates = new HashMap<>();\n\t\tcurrencyRates.put(\"AUDUSD\", 0.8371);\n\t\tcurrencyRates.put(\"CADUSD\", 0.8711);\n\t\tcurrencyRates.put(\"CNYUSD\", 6.1715);\n\t\tcurrencyRates.put(\"EURUSD\", 1.2315);\n\t\tcurrencyRates.put(\"GBPUSD\", 1.5683);\n\t\tcurrencyRates.put(\"NZDUSD\", 0.7750);\n\t\tcurrencyRates.put(\"USDJPY\", 119.95);\n\t\tcurrencyRates.put(\"EURCZK\", 27.6028);\n\t\tcurrencyRates.put(\"EURDKK\", 7.4405);\n\t\tcurrencyRates.put(\"EURNOK\", 8.6651);\n\t\t\n\t\treturn currencyRates;\n\t\t\n\t}", "public void setCurrency(Currency usd) {\n\t\t\n\t}", "public void addCurrency(String csymbol, String cname, BigDecimal crate, BigDecimal cunit) {\n CurrencyExchangeRateBean bean = new CurrencyExchangeRateBean();\n bean.setCurrencyId(csymbol);\n bean.setExchangeRate(crate);\n bean.setUnit(cunit);\n currencies.add(bean);\n }", "public void addCurrency(String csymbol, String cname, BigDecimal crate, BigDecimal cunit) {\n CurrencyExchangeRateBean bean = new CurrencyExchangeRateBean();\n bean.setCurrencyId(csymbol);\n bean.setExchangeRate(crate);\n bean.setUnit(cunit);\n currencies.add(bean);\n }", "public void setCurrency(CurrencyUnit currency) {\r\n this.currency = currency;\r\n }", "Unit getUnit();", "public String getCurrencyCode() {\n\t\treturn currencyCode;\n\t}", "public Currency(String country,double value, double valueUSD){\n this.country = country;\n this.value = value;\n this.valueUSD = valueUSD;\n}", "public void setCurrencyCode(final String currencyCode) {\n\t\tthis.currencyCode = currencyCode;\n\t}", "public Symbol create(char input) {\n if (cacheSymbol.containsKey(input)) {\n return cacheSymbol.get(input);\n } else {\n Symbol symbol = (Symbol) Factory.getInstance().create(TypeData.SYMBOL);\n symbol.setSymbol(input);\n cacheSymbol.put(input, symbol);\n return symbol;\n }\n }", "public void setKcUnitName(String kcUnitName) {\n this.kcUnitName = kcUnitName;\n }", "public final flipsParser.angularRateUnit_return angularRateUnit() throws RecognitionException {\n flipsParser.angularRateUnit_return retval = new flipsParser.angularRateUnit_return();\n retval.start = input.LT(1);\n\n CommonTree root_0 = null;\n\n Token string_literal491=null;\n Token string_literal492=null;\n Token string_literal493=null;\n Token string_literal494=null;\n Token string_literal495=null;\n Token string_literal496=null;\n Token string_literal497=null;\n Token Per498=null;\n flipsParser.timeUnit_return timeUnit499 = null;\n\n\n CommonTree string_literal491_tree=null;\n CommonTree string_literal492_tree=null;\n CommonTree string_literal493_tree=null;\n CommonTree string_literal494_tree=null;\n CommonTree string_literal495_tree=null;\n CommonTree string_literal496_tree=null;\n CommonTree string_literal497_tree=null;\n CommonTree Per498_tree=null;\n RewriteRuleTokenStream stream_Per=new RewriteRuleTokenStream(adaptor,\"token Per\");\n RewriteRuleTokenStream stream_327=new RewriteRuleTokenStream(adaptor,\"token 327\");\n RewriteRuleTokenStream stream_328=new RewriteRuleTokenStream(adaptor,\"token 328\");\n RewriteRuleTokenStream stream_323=new RewriteRuleTokenStream(adaptor,\"token 323\");\n RewriteRuleTokenStream stream_324=new RewriteRuleTokenStream(adaptor,\"token 324\");\n RewriteRuleTokenStream stream_325=new RewriteRuleTokenStream(adaptor,\"token 325\");\n RewriteRuleTokenStream stream_326=new RewriteRuleTokenStream(adaptor,\"token 326\");\n RewriteRuleTokenStream stream_322=new RewriteRuleTokenStream(adaptor,\"token 322\");\n RewriteRuleSubtreeStream stream_timeUnit=new RewriteRuleSubtreeStream(adaptor,\"rule timeUnit\");\n try {\n // flips.g:716:2: ( 'rpm' -> REVOLUTION MINUTE | ( 'hz' | 'hertz' ) -> REVOLUTION SECOND | ( 'rev' | 'revs' | 'revolution' | 'revolutions' ) Per timeUnit -> REVOLUTION timeUnit )\n int alt193=3;\n switch ( input.LA(1) ) {\n case 322:\n {\n alt193=1;\n }\n break;\n case 323:\n case 324:\n {\n alt193=2;\n }\n break;\n case 325:\n case 326:\n case 327:\n case 328:\n {\n alt193=3;\n }\n break;\n default:\n NoViableAltException nvae =\n new NoViableAltException(\"\", 193, 0, input);\n\n throw nvae;\n }\n\n switch (alt193) {\n case 1 :\n // flips.g:716:4: 'rpm'\n {\n string_literal491=(Token)match(input,322,FOLLOW_322_in_angularRateUnit4166); \n stream_322.add(string_literal491);\n\n\n\n // AST REWRITE\n // elements: \n // token labels: \n // rule labels: retval\n // token list labels: \n // rule list labels: \n // wildcard labels: \n retval.tree = root_0;\n RewriteRuleSubtreeStream stream_retval=new RewriteRuleSubtreeStream(adaptor,\"rule retval\",retval!=null?retval.tree:null);\n\n root_0 = (CommonTree)adaptor.nil();\n // 717:2: -> REVOLUTION MINUTE\n {\n adaptor.addChild(root_0, (CommonTree)adaptor.create(REVOLUTION, \"REVOLUTION\"));\n adaptor.addChild(root_0, (CommonTree)adaptor.create(MINUTE, \"MINUTE\"));\n\n }\n\n retval.tree = root_0;\n }\n break;\n case 2 :\n // flips.g:718:4: ( 'hz' | 'hertz' )\n {\n // flips.g:718:4: ( 'hz' | 'hertz' )\n int alt191=2;\n int LA191_0 = input.LA(1);\n\n if ( (LA191_0==323) ) {\n alt191=1;\n }\n else if ( (LA191_0==324) ) {\n alt191=2;\n }\n else {\n NoViableAltException nvae =\n new NoViableAltException(\"\", 191, 0, input);\n\n throw nvae;\n }\n switch (alt191) {\n case 1 :\n // flips.g:718:5: 'hz'\n {\n string_literal492=(Token)match(input,323,FOLLOW_323_in_angularRateUnit4179); \n stream_323.add(string_literal492);\n\n\n }\n break;\n case 2 :\n // flips.g:718:10: 'hertz'\n {\n string_literal493=(Token)match(input,324,FOLLOW_324_in_angularRateUnit4181); \n stream_324.add(string_literal493);\n\n\n }\n break;\n\n }\n\n\n\n // AST REWRITE\n // elements: \n // token labels: \n // rule labels: retval\n // token list labels: \n // rule list labels: \n // wildcard labels: \n retval.tree = root_0;\n RewriteRuleSubtreeStream stream_retval=new RewriteRuleSubtreeStream(adaptor,\"rule retval\",retval!=null?retval.tree:null);\n\n root_0 = (CommonTree)adaptor.nil();\n // 719:2: -> REVOLUTION SECOND\n {\n adaptor.addChild(root_0, (CommonTree)adaptor.create(REVOLUTION, \"REVOLUTION\"));\n adaptor.addChild(root_0, (CommonTree)adaptor.create(SECOND, \"SECOND\"));\n\n }\n\n retval.tree = root_0;\n }\n break;\n case 3 :\n // flips.g:720:4: ( 'rev' | 'revs' | 'revolution' | 'revolutions' ) Per timeUnit\n {\n // flips.g:720:4: ( 'rev' | 'revs' | 'revolution' | 'revolutions' )\n int alt192=4;\n switch ( input.LA(1) ) {\n case 325:\n {\n alt192=1;\n }\n break;\n case 326:\n {\n alt192=2;\n }\n break;\n case 327:\n {\n alt192=3;\n }\n break;\n case 328:\n {\n alt192=4;\n }\n break;\n default:\n NoViableAltException nvae =\n new NoViableAltException(\"\", 192, 0, input);\n\n throw nvae;\n }\n\n switch (alt192) {\n case 1 :\n // flips.g:720:5: 'rev'\n {\n string_literal494=(Token)match(input,325,FOLLOW_325_in_angularRateUnit4195); \n stream_325.add(string_literal494);\n\n\n }\n break;\n case 2 :\n // flips.g:720:11: 'revs'\n {\n string_literal495=(Token)match(input,326,FOLLOW_326_in_angularRateUnit4197); \n stream_326.add(string_literal495);\n\n\n }\n break;\n case 3 :\n // flips.g:720:18: 'revolution'\n {\n string_literal496=(Token)match(input,327,FOLLOW_327_in_angularRateUnit4199); \n stream_327.add(string_literal496);\n\n\n }\n break;\n case 4 :\n // flips.g:720:31: 'revolutions'\n {\n string_literal497=(Token)match(input,328,FOLLOW_328_in_angularRateUnit4201); \n stream_328.add(string_literal497);\n\n\n }\n break;\n\n }\n\n Per498=(Token)match(input,Per,FOLLOW_Per_in_angularRateUnit4204); \n stream_Per.add(Per498);\n\n pushFollow(FOLLOW_timeUnit_in_angularRateUnit4206);\n timeUnit499=timeUnit();\n\n state._fsp--;\n\n stream_timeUnit.add(timeUnit499.getTree());\n\n\n // AST REWRITE\n // elements: timeUnit\n // token labels: \n // rule labels: retval\n // token list labels: \n // rule list labels: \n // wildcard labels: \n retval.tree = root_0;\n RewriteRuleSubtreeStream stream_retval=new RewriteRuleSubtreeStream(adaptor,\"rule retval\",retval!=null?retval.tree:null);\n\n root_0 = (CommonTree)adaptor.nil();\n // 721:2: -> REVOLUTION timeUnit\n {\n adaptor.addChild(root_0, (CommonTree)adaptor.create(REVOLUTION, \"REVOLUTION\"));\n adaptor.addChild(root_0, stream_timeUnit.nextTree());\n\n }\n\n retval.tree = root_0;\n }\n break;\n\n }\n retval.stop = input.LT(-1);\n\n retval.tree = (CommonTree)adaptor.rulePostProcessing(root_0);\n adaptor.setTokenBoundaries(retval.tree, retval.start, retval.stop);\n\n }\n catch (RecognitionException re) {\n reportError(re);\n recover(input,re);\n \tretval.tree = (CommonTree)adaptor.errorNode(input, retval.start, input.LT(-1), re);\n\n }\n finally {\n }\n return retval;\n }", "public CurrencyUnit getCurrency() {\r\n return currency;\r\n }", "public void setUnit(String unit) {\n\t\tthis.unit = unit;\n\t}", "public String getUnit();", "private String formatUsNumber(Editable text) {\n\t\tStringBuilder cashAmountBuilder = null;\n\t\tString USCurrencyFormat = text.toString();\n//\t\tif (!text.toString().matches(\"^\\\\$(\\\\d{1,3}(\\\\,\\\\d{3})*|(\\\\d+))(\\\\.\\\\d{2})?$\")) { \n\t\t\tString userInput = \"\" + text.toString().replaceAll(\"[^\\\\d]\", \"\");\n\t\t\tcashAmountBuilder = new StringBuilder(userInput);\n\n\t\t\twhile (cashAmountBuilder.length() > 3 && cashAmountBuilder.charAt(0) == '0') {\n\t\t\t\tcashAmountBuilder.deleteCharAt(0);\n\t\t\t}\n\t\t\twhile (cashAmountBuilder.length() < 3) {\n\t\t\t\tcashAmountBuilder.insert(0, '0');\n\t\t\t}\n\t\t\tcashAmountBuilder.insert(cashAmountBuilder.length() - 2, '.');\n\t\t\tUSCurrencyFormat = cashAmountBuilder.toString();\n\t\t\tUSCurrencyFormat = Util.getdoubleUSPriceFormat(Double.parseDouble(USCurrencyFormat));\n\n//\t\t}\n\t\tif(\"0.00\".equals(USCurrencyFormat)){\n\t\t\treturn \"\";\n\t\t}\n\t\tif(!USCurrencyFormat.contains(\"$\"))\n\t\t\treturn \"$\"+USCurrencyFormat;\n\t\treturn USCurrencyFormat;\n\t}", "public String getUnitcd() {\r\n return unitcd;\r\n }", "public Unit(float length, float width, float height, float totalCost, String unitKind, Furniture furniture, Electrictiy electrictiy, Wall wall, Roof roof, Floor floor) {\n this.length = length;\n this.width = width;\n this.height = height;\n this.totalCost = totalCost;\n this.unitKind = unitKind;\n this.furniture = furniture;\n this.electrictiy = electrictiy;\n this.wall = wall;\n this.roof = roof;\n this.floor = floor;\n }", "public static Currency createCurrency (String country) {\n\n\t\tswitch(country.toUpperCase()) {\n\t\t\n\t\tcase \"INDIA\" : \n\t\t\treturn new Rupee(); \n\t\t\n\t\tcase \"SINGAPORE\" : \n\t\t\treturn new SGDDollar(); \n\t\t\n\t\tcase \"US\" : \n\t\t\treturn new USDollar();\n\t\t\n\t\tdefault : \n\t\t\tthrow new IllegalArgumentException(\"No such currency\");\n\t\t}\n\t}", "public void setUnitsAbbr(String abbr) { unitsAbbr = abbr; }", "public int getUnitNum(){\n\t\treturn Integer.parseInt(unitNumLbl.getText());\n\t}", "public void setUnit(Unit unit) {\r\n\t\tthis.unit = unit;\r\n\t}", "public CodeUnit getCodeUnitAt(Address addr);", "Currency getCurrency();", "public String getUnit() {\n\t\treturn unit;\n\t}", "public product_uom getBaseUoM_byCategory(Integer category) {\r\n\t\t// use caching\r\n\t\tif (baseunits.containsKey(category))\r\n\t\t\treturn baseunits.get(category);\r\n\r\n\t\tOpenERPDomain domain = new OpenERPDomain();\r\n\t\tdomain.add(\"category_id\", category);\r\n\t\tdomain.add(\"uom_type\", \"=\", \"reference\");\r\n\t\tObject[] ids = openerp.search(\"product.uom\", domain);\r\n\r\n\t\tif (ids == null)\r\n\t\t\treturn null;\r\n\r\n\t\tInteger id = null;\r\n\t\tif (ids.length > 0)\r\n\t\t\tid = (Integer) ids[0];\r\n\r\n\t\tif (id == null)\r\n\t\t\treturn null;\r\n\r\n\t\tproduct_uom p = new product_uom(openerp, id);\r\n\t\tbaseunits.put(id, p);\r\n\t\treturn p;\r\n\t}", "com.google.protobuf.StringValueOrBuilder getCurrencyCodeOrBuilder();" ]
[ "0.6478456", "0.5717727", "0.5683488", "0.5413608", "0.5358906", "0.52889323", "0.5185299", "0.5164495", "0.5127171", "0.5083051", "0.50124305", "0.49411076", "0.49340224", "0.49236232", "0.48916444", "0.4890748", "0.48904678", "0.48754779", "0.48597756", "0.48147592", "0.4812493", "0.4808032", "0.47981697", "0.47937045", "0.47801587", "0.47774658", "0.4769415", "0.47513077", "0.47391692", "0.47382453", "0.47355092", "0.4723438", "0.47198138", "0.47145766", "0.4711804", "0.47107184", "0.46627796", "0.4660061", "0.46521515", "0.46508712", "0.46504748", "0.46400347", "0.46398562", "0.4625471", "0.46236876", "0.46225366", "0.46217176", "0.46183768", "0.46047994", "0.4600722", "0.459647", "0.45927835", "0.4590807", "0.45890483", "0.45878184", "0.45830444", "0.45815593", "0.4578146", "0.457382", "0.4567208", "0.4559818", "0.45593092", "0.4557881", "0.4557348", "0.4554484", "0.45537546", "0.45507127", "0.45480335", "0.4544519", "0.4541424", "0.45353678", "0.45326096", "0.4529947", "0.4526224", "0.45237547", "0.4511199", "0.4511199", "0.45042664", "0.44934815", "0.44925407", "0.44922653", "0.44907898", "0.44844753", "0.4476178", "0.44558194", "0.44551393", "0.44506595", "0.44492325", "0.44466397", "0.44443828", "0.4444128", "0.44384664", "0.4438087", "0.44346333", "0.44329855", "0.4432415", "0.44280046", "0.4423331", "0.44209316", "0.44205916" ]
0.63259053
1
Returns the currency for the country of the given locale.
public static Currency getInstance(Locale locale) { String code = java.util.Currency.getInstance(locale).getCurrencyCode(); return new Currency(code); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "Currency getCurrency();", "com.google.ads.googleads.v6.resources.CurrencyConstant getCurrencyConstant();", "public Pokemon.Currency getCurrency() {\n if (currencyBuilder_ == null) {\n return currency_;\n } else {\n return currencyBuilder_.getMessage();\n }\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\r\n return currency;\r\n }", "private static String getCountryLocale() {\n return Locale.getDefault().getCountry();\n }", "@GET\r\n\t@Path(\"/code/{currencycode}\")\r\n\tpublic String getCountryByCurrencyCode(@PathParam(\"currencycode\") final Currency currency) {\r\n\t\treturn currency.getCountry();\r\n\t}", "public String getCurrency()\r\n {\r\n return currency;\r\n }", "public String getCurrency()\n\t{\n\t\treturn this.currency;\n\t}", "public static Currency createCurrency (String country) {\n\n\t\tswitch(country.toUpperCase()) {\n\t\t\n\t\tcase \"INDIA\" : \n\t\t\treturn new Rupee(); \n\t\t\n\t\tcase \"SINGAPORE\" : \n\t\t\treturn new SGDDollar(); \n\t\t\n\t\tcase \"US\" : \n\t\t\treturn new USDollar();\n\t\t\n\t\tdefault : \n\t\t\tthrow new IllegalArgumentException(\"No such currency\");\n\t\t}\n\t}", "public String getCurrency() {\n return this.currency;\n }", "@Override\n public String getCurrency() {\n return currency != null ? currency : App.getContext().getString(R.string.example_currency);\n }", "public java.lang.String getCurrency() {\n return currency;\n }", "java.lang.String getLocale();", "public java.lang.String getCurrency() {\r\n return currency;\r\n }", "public Pokemon.Currency getCurrency() {\n return currency_;\n }", "public java.math.BigDecimal getValue_Local_Currency() {\r\n return value_Local_Currency;\r\n }", "public BigDecimal getCURRENCY() {\r\n return CURRENCY;\r\n }", "public Currency getCurrency();", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public java.lang.String getCurrency()\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.SimpleValue target = null;\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_element_user(CURRENCY$10, 0);\n if (target == null)\n {\n return null;\n }\n return target.getStringValue();\n }\n }", "com.google.ads.googleads.v6.resources.CurrencyConstantOrBuilder getCurrencyConstantOrBuilder();", "private String currencyFormat(BigDecimal amount) {\n return NumberFormat.getCurrencyInstance(getLocalCurrency().getLocale()).format(amount);\n }", "public String getUserCurrency() {\n return sessionData.getUserCurrency();\n }", "public de.htwg_konstanz.ebus.framework.wholesaler.vo.Currency getCurrency () {\r\n\t\treturn currency;\r\n\t}", "public CurrencyUnit getCurrency() {\r\n return currency;\r\n }", "protected String getCurrency() {\n return currency;\n }", "public String getCurrency1() {\r\n\t\treturn currency1;\r\n\t}", "com.google.protobuf.StringValue getCurrencyCode();", "public Currency getCurrency() {\n return currencyCode;\n }", "public static String getCountry(final String rfcLocale) {\n return rfcLocale.contains(DASH)\n ? rfcLocale.toUpperCase(Locale.ENGLISH).substring(3)\n : \"\";\n }", "public Object getCurrency() {\n\t\treturn null;\n\t}", "public String getLanguageValue(Locale locale) {\n\n\t\tString language = locale.getDisplayLanguage(this.locale);\n\t\t\n\t\tif(language.length() > 0) {\n\t\t\tlanguage = language.substring(0, 1).toUpperCase(this.locale) + language.substring(1);\n\t\t}\n\t\t\n\t\tString country = locale.getDisplayCountry(); \n\t\t\n\t\tif(country.length() > 0) {\n\t\t\tlanguage = language + \" - \" + locale.getDisplayCountry(this.locale); \n\t\t}\n\t\t\n\t\tString variant = locale.getDisplayVariant(); \n\n\t\tif(variant.length() > 0) {\n\t\t\tlanguage = language + \" - \" + locale.getDisplayVariant(this.locale); \n\t\t}\n\t\t\n\t\tif(locale == fallbackLocale) {\n\t\t\tlanguage = language + \" (fallback)\";\n\t\t}\n\t\t\n\t\treturn language;\n\t}", "public Pokemon.CurrencyOrBuilder getCurrencyOrBuilder() {\n if (currencyBuilder_ != null) {\n return currencyBuilder_.getMessageOrBuilder();\n } else {\n return currency_;\n }\n }", "@RequestMapping(value = \"/getCountries\", method = RequestMethod.GET, produces = \"application/json\")\n @ResponseBody\n public SPResponse getCountries(@RequestParam(defaultValue = \"en_US\") String locale) {\n \n locale = LocaleHelper.isSupported(locale);\n \n String countryList = countryListMap.get(locale);\n \n if (countryList == null) {\n String fileName = null;\n if (Constants.DEFAULT_LOCALE.equalsIgnoreCase(locale)) {\n fileName = \"countryList.json\";\n } else {\n fileName = \"countryList_\" + locale.toString() + \".json\";\n }\n \n ObjectMapper mapper = new ObjectMapper();\n try {\n Resource resource = resourceLoader.getResource(\"classpath:\" + fileName);\n Countries readValue = mapper.readValue(resource.getFile(), Countries.class);\n countryList = mapper.writeValueAsString(readValue);\n } catch (Exception e) {\n LOG.error(\"error occurred retreving the country list for the locale \" + locale + \": file :\"\n + fileName, e);\n Resource resource = resourceLoader.getResource(\"classpath:countryList.json\");\n Countries readValue;\n try {\n readValue = mapper.readValue(resource.getFile(), Countries.class);\n countryList = mapper.writeValueAsString(readValue);\n } catch (IOException e1) {\n LOG.error(\"Error occurred while getting the country list\", e1);\n }\n }\n \n if (countryList == null) {\n countryList = MessagesHelper.getMessage(\"countries.list\");\n } else {\n countryListMap.put(locale, countryList);\n }\n }\n return new SPResponse().add(\"countries\", countryList);\n }", "public Currency findCurrencyByCode(String currency);", "String getSettlementCurrency();", "public String getCurrencyCode() {\n return currencyCode;\n }", "String getTradeCurrency();", "public String getPaymentCurrency() {\n return _paymentCurrency;\n }", "public String getCurrency() {\n return (String) getAttributeInternal(CURRENCY);\n }", "public String getCurrencyCode() {\n return mCurrencyCode;\n }", "public DecimalFormat getCurrencyFormat(String currency) {\n return _getNumberFormat(currency, CURRENCY, null, null);\n }", "@Override\n public Currency getCurrency() {\n return currency;\n }", "public ConversionFactorResponse getCurrencyConvertFactor(String CountryCode) {\n\t\tConversionFactorRequest newRequest = new ConversionFactorRequest(CountryCode);\n\t\tConversionFactorResponse convertfactorResponse = currencyFactorMS.getConvertFactor(newRequest);\n\t\treturn convertfactorResponse;\n\t\t\n\t}", "@Override\n\tpublic String getCurrency(){\n\t\treturn MARLAY_CURR;\n\t}", "Uom getCurrencyUom();", "public String getCurrencyCode() {\n\t\treturn currencyCode;\n\t}", "public Pokemon.CurrencyOrBuilder getCurrencyOrBuilder() {\n return currency_;\n }", "public java.lang.String couponCurrency()\n\t{\n\t\treturn _lsPeriod.get (_lsPeriod.size() - 1).couponCurrency();\n\t}", "String getLocalizedString(Locale locale);", "Country getCountry();", "public ULocale getLocale() {\r\n return this.locale;\r\n }", "public String getLocale() {\n return this.locale;\n }", "@Override\n @Nullable\n public Currency getCurrency(String key) {\n return currencies.get(key);\n }", "java.lang.String getCountry();", "java.lang.String getCountry();", "public String get_currency_name() {\n\t\treturn name;\r\n\t}", "public static String getDisplayCountry(String localeID, ULocale displayLocale) {\n/* 648 */ throw new RuntimeException(\"Stub!\");\n/* */ }", "ULocale getLocale() {\n\t\treturn locale;\n\t}", "com.google.protobuf.ByteString\n getLocaleBytes();", "public Currency getCurrency1() {\n return _underlyingForex.getCurrency1();\n }", "public String getLocale ( ) {\n\t\treturn extract ( handle -> getLocale ( ) );\n\t}", "TokenlyCurrency getCurrencyType();", "@Nonnull public CountryCode getCountry() { return country; }", "public String getAccountCurrencyCode() {\r\n return accountCurrencyCode;\r\n }", "public java.lang.String getCountryRateOrDefault(\n java.lang.String key,\n java.lang.String defaultValue) {\n if (key == null) { throw new java.lang.NullPointerException(); }\n java.util.Map<java.lang.String, java.lang.String> map =\n internalGetCountryRate().getMap();\n return map.containsKey(key) ? map.get(key) : defaultValue;\n }", "public Locale getLocale() { return this.locale; }", "public String getDisplayCountry(ULocale displayLocale) {\n/* 624 */ throw new RuntimeException(\"Stub!\");\n/* */ }", "public String getCurrencyCode()\r\n {\r\n return (m_currencyCode);\r\n }", "public static Locale getLocale() {\n return localeInfo.get();\n }", "public String getLocalCurrencyAmount() {\n return sendLocalCurrencyAmount;\n }", "public BigDecimal getCurrency1() {\n\treturn currency1;\n}", "public Locale getLocale() {\n return locale;\n }", "public Locale getLocale() {\n return locale;\n }", "public Locale getLocale() {\n return locale;\n }", "public Locale getLocale()\n {\n return locale;\n }", "public Locale getLocale() {\r\n return locale;\r\n }", "Pokemon.Currency getCurrency();", "public java.lang.String getCountryRateOrDefault(\n java.lang.String key,\n java.lang.String defaultValue) {\n if (key == null) { throw new java.lang.NullPointerException(); }\n java.util.Map<java.lang.String, java.lang.String> map =\n internalGetCountryRate().getMap();\n return map.containsKey(key) ? map.get(key) : defaultValue;\n }", "public String getFromCurrencyCode() {\n return fromCurrencyCode;\n }", "public String getSplitCurrency() {\r\n\treturn fxndf.getSplitCurrency();\r\n }", "public Locale getLocale () {\n\t\treturn locale;\n\t}", "public final String getCountry() {\n\t\treturn country;\n\t}", "public Currency getCurrency2() {\n return _underlyingForex.getCurrency2();\n }", "@ApiModelProperty(value = \"The locale of the contained data\")\n public String getLocale() {\n return locale;\n }", "java.lang.String getCountryCode();", "java.lang.String getCountryCode();", "public static String getCountry(String localeID) {\n/* 284 */ throw new RuntimeException(\"Stub!\");\n/* */ }", "public String getCountry() {\r\n\t\treturn country;\r\n\t}", "public String getCountry() {\r\n\t\treturn country;\r\n\t}", "public String getCountry() {\r\n\t\treturn country;\r\n\t}", "public java.lang.String getCountry() {\n return country;\n }", "public BigDecimal getCurrency2() {\n\treturn currency2;\n}", "public String getCurrencyCd() {\n return (String) getAttributeInternal(CURRENCYCD);\n }" ]
[ "0.60687137", "0.58482987", "0.5796933", "0.5742888", "0.5742888", "0.5742888", "0.5742888", "0.57042474", "0.5669697", "0.5631312", "0.55858696", "0.5562916", "0.55618846", "0.5539181", "0.5522759", "0.55176276", "0.5495793", "0.54729366", "0.544468", "0.5425167", "0.54163486", "0.54080224", "0.53892756", "0.53892756", "0.53892756", "0.53392917", "0.5325651", "0.5311016", "0.5305644", "0.5294545", "0.5291836", "0.5285309", "0.52567255", "0.52521473", "0.52518374", "0.52248544", "0.5189202", "0.51891476", "0.5187212", "0.51789874", "0.51787466", "0.51605725", "0.5156489", "0.51372516", "0.5132315", "0.5132301", "0.5114572", "0.5100234", "0.50542885", "0.5046919", "0.5039082", "0.50345224", "0.50214475", "0.50059634", "0.49970523", "0.49946347", "0.49697688", "0.4965589", "0.4956169", "0.49494612", "0.49450678", "0.49450678", "0.49318007", "0.491915", "0.4914151", "0.49061626", "0.48910785", "0.48779806", "0.48748952", "0.48500934", "0.48376125", "0.48373207", "0.48308524", "0.4828713", "0.48217905", "0.48072833", "0.47982466", "0.4794985", "0.47911507", "0.47911507", "0.47911507", "0.47855312", "0.4784547", "0.4766968", "0.47660047", "0.4762809", "0.4758607", "0.4738998", "0.4738538", "0.4732706", "0.47317234", "0.4716755", "0.4716755", "0.47130004", "0.47128996", "0.47128996", "0.47128996", "0.47109413", "0.47093034", "0.47046316" ]
0.6930758
0
Returns the currency code for this currency.
public String getCode() { return _code; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public String getCurrencyCode() {\n\t\treturn currencyCode;\n\t}", "public String getCurrencyCode()\r\n {\r\n return (m_currencyCode);\r\n }", "com.google.protobuf.StringValue getCurrencyCode();", "public String getCurrencyCode() {\n return currencyCode;\n }", "public String getCurrencyCode() {\n return mCurrencyCode;\n }", "public String getAccountCurrencyCode() {\r\n return accountCurrencyCode;\r\n }", "public String getCurrencyCd() {\n return (String) getAttributeInternal(CURRENCYCD);\n }", "public Currency getCurrency() {\n return currencyCode;\n }", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public BigDecimal getCURRENCY_CODE() {\r\n return CURRENCY_CODE;\r\n }", "public Pokemon.Currency getCurrency() {\n if (currencyBuilder_ == null) {\n return currency_;\n } else {\n return currencyBuilder_.getMessage();\n }\n }", "public String getCurrencyID() {\n return currencyID;\n }", "@Override\n\tpublic String getCurrencyCode() {\n\t\treturn null;\n\t}", "public String getFromCurrencyCode() {\n return fromCurrencyCode;\n }", "public String getCurrencyID() {\n return currencyID;\n }", "public String getDefaultDisplayCurrencyCode() {\n return (String) get(\"default_display_currency_code\");\n }", "public String getCurrencyid() {\n return currencyid;\n }", "public java.lang.String getCurrency() {\n return currency;\n }", "public String getCurrency()\n\t{\n\t\treturn this.currency;\n\t}", "public java.lang.String couponCurrency()\n\t{\n\t\treturn _lsPeriod.get (_lsPeriod.size() - 1).couponCurrency();\n\t}", "public BigDecimal getCODE() {\r\n return CODE;\r\n }", "public BigDecimal getCODE() {\r\n return CODE;\r\n }", "public java.lang.String getCurrency() {\r\n return currency;\r\n }", "public String getCurrency() {\n return (String) getAttributeInternal(CURRENCY);\n }", "@Override\n\tpublic int getC_Currency_ID() {\n\t\treturn 0;\n\t}", "public java.lang.String getCurrency()\n {\n synchronized (monitor())\n {\n check_orphaned();\n org.apache.xmlbeans.SimpleValue target = null;\n target = (org.apache.xmlbeans.SimpleValue)get_store().find_element_user(CURRENCY$10, 0);\n if (target == null)\n {\n return null;\n }\n return target.getStringValue();\n }\n }", "public String getCurrency() {\r\n return currency;\r\n }", "public de.htwg_konstanz.ebus.framework.wholesaler.vo.Currency getCurrency () {\r\n\t\treturn currency;\r\n\t}", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "public String getCurrency() {\n return currency;\n }", "Currency getCurrency();", "com.google.protobuf.StringValueOrBuilder getCurrencyCodeOrBuilder();", "@Array({4}) \n\t@Field(27) \n\tpublic Pointer<Byte > CurrencyID() {\n\t\treturn this.io.getPointerField(this, 27);\n\t}", "public String getCurrency()\r\n {\r\n return currency;\r\n }", "public java.lang.String payCurrency()\n\t{\n\t\treturn _lsPeriod.get (_lsPeriod.size() - 1).payCurrency();\n\t}", "public Currency findCurrencyByCode(String currency);", "public String getCurrencyISO() {\n return MCurrency.getISO_Code(getCtx(), getC_Currency_ID());\n }", "Long getCurrencyId();", "com.google.ads.googleads.v6.resources.CurrencyConstant getCurrencyConstant();", "public String getCurrency() {\n return this.currency;\n }", "@Override\n public String getCurrency() {\n return currency != null ? currency : App.getContext().getString(R.string.example_currency);\n }", "public Pokemon.Currency getCurrency() {\n return currency_;\n }", "@Override\n\tpublic String getCurrency(){\n\t\treturn MARLAY_CURR;\n\t}", "protected String getCurrency() {\n return currency;\n }", "public Integer getGameCurrencyid() {\n return gameCurrencyid;\n }", "public int getC_Currency_ID();", "@ApiModelProperty(value = \"Currency code of the master account organization\")\n public String getCurrencyCode() {\n return currencyCode;\n }", "public java.lang.Integer getBasecurrency() {\n\treturn basecurrency;\n}", "public java.lang.String getBillingCurrencyNumericCode() {\r\n return billingCurrencyNumericCode;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public BigDecimal getCOMP_CODE() {\r\n return COMP_CODE;\r\n }", "public String getTradeCurrency() {\n Object ref = tradeCurrency_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n tradeCurrency_ = s;\n }\n return s;\n }\n }", "public String get_currency_name() {\n\t\treturn name;\r\n\t}", "public String getTradeCurrency() {\n Object ref = tradeCurrency_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n tradeCurrency_ = s;\n }\n return s;\n } else {\n return (String) ref;\n }\n }", "public Currency getCurrency() {\n return _iborIndex.getCurrency();\n }", "String getTradeCurrency();", "public Currency getCurrency() {\n return _index.getIborIndex().getCurrency();\n }", "public String getSettlementCurrency() {\n Object ref = settlementCurrency_;\n if (ref instanceof String) {\n return (String) ref;\n } else {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n settlementCurrency_ = s;\n }\n return s;\n }\n }", "public String getCurrencyPair() {\n return _ccyPair;\n }", "String getSettlementCurrency();", "public String getSettlementCurrency() {\n Object ref = settlementCurrency_;\n if (!(ref instanceof String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n settlementCurrency_ = s;\n }\n return s;\n } else {\n return (String) ref;\n }\n }", "@Override\n @Nullable\n public Currency getCurrency(String key) {\n return currencies.get(key);\n }", "public String getContractCode() {\n return contractCode;\n }", "public String getcCode() {\n\t\treturn this.cCode;\n\t}", "public Currency getCurrency();", "public java.lang.Long getBASECURRENCYID() {\n return BASE_CURRENCY_ID;\n }", "public Object getCurrency() {\n\t\treturn null;\n\t}", "public java.lang.Long getBASECURRENCYID() {\n return BASE_CURRENCY_ID;\n }", "public String getCurrency1() {\r\n\t\treturn currency1;\r\n\t}", "public String getCountryCode() {\n return normalizedBic.substring(COUNTRY_CODE_INDEX, COUNTRY_CODE_INDEX + COUNTRY_CODE_LENGTH);\n }", "public String getUserCurrency() {\n return sessionData.getUserCurrency();\n }", "public String getCoinCode() {\n return coinCode;\n }", "public BigDecimal getCURRENCY() {\r\n return CURRENCY;\r\n }", "public Price currencyCode(String currencyCode) {\n this.currencyCode = currencyCode;\n return this;\n }", "TokenlyCurrency getCurrencyType();", "public String getPaymentCurrency() {\n return _paymentCurrency;\n }", "public BigDecimal getCHARGE_CODE() {\r\n return CHARGE_CODE;\r\n }", "@Override\n public Currency getCurrency() {\n return currency;\n }", "public String getCode() {\n return (String) get(\"code\");\n }", "public String code() {\r\n return code == null ? String.format(\"%s%04d\", type, num) : code;\r\n }", "public String getCardCode() {\n\t\t\treturn cardCode;\n\t\t}", "public String getCompCode() {\n return (String)getAttributeInternal(COMPCODE);\n }", "@GET\r\n\t@Path(\"/code/{currencycode}\")\r\n\tpublic String getCountryByCurrencyCode(@PathParam(\"currencycode\") final Currency currency) {\r\n\t\treturn currency.getCountry();\r\n\t}", "public java.lang.String getPayComCode() {\n return payComCode;\n }", "public com.google.protobuf.ByteString\n getTradeCurrencyBytes() {\n Object ref = tradeCurrency_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n tradeCurrency_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }", "public CurrencyCode getAuthorizationCurrencyCode() {\n return authorizationCurrencyCode;\n }", "public com.google.protobuf.ByteString\n getTradeCurrencyBytes() {\n Object ref = tradeCurrency_;\n if (ref instanceof String) {\n com.google.protobuf.ByteString b =\n com.google.protobuf.ByteString.copyFromUtf8(\n (String) ref);\n tradeCurrency_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }", "public String getCode() {\n return super.getString(Constants.Properties.CODE);\n }", "public String getCurrencySymbol()\r\n {\r\n return (m_currencySymbol);\r\n }", "public Currency(String code) {\n _code = code;\n UnitFormatImpl.getInstance().getSymbolMap().label(this, code);\n }", "public abstract String getCurrencyType();", "@ApiModelProperty(required = true, value = \"Sofort currency code. For example, **EUR**.\")\n @JsonProperty(JSON_PROPERTY_CURRENCY_CODE)\n @JsonInclude(value = JsonInclude.Include.USE_DEFAULTS)\n\n public String getCurrencyCode() {\n return currencyCode;\n }" ]
[ "0.7569751", "0.75657195", "0.7564407", "0.74672455", "0.7384697", "0.6917925", "0.6872157", "0.6866739", "0.6846752", "0.6846752", "0.6846752", "0.6778326", "0.67521125", "0.67002106", "0.6674115", "0.66420454", "0.66248363", "0.6571028", "0.6546925", "0.6526476", "0.651697", "0.6505527", "0.6505527", "0.6503351", "0.6470585", "0.64493763", "0.64340115", "0.64317673", "0.6428935", "0.6425839", "0.6425839", "0.6425839", "0.6425839", "0.636027", "0.635352", "0.6352762", "0.63489115", "0.63053805", "0.6284041", "0.6269708", "0.62562793", "0.623868", "0.62288934", "0.6218571", "0.62142724", "0.62109196", "0.62072486", "0.61998624", "0.61874", "0.61717236", "0.6169575", "0.61637145", "0.61576706", "0.61576706", "0.61576706", "0.61576706", "0.61576706", "0.61576706", "0.61576706", "0.61576706", "0.6151794", "0.613592", "0.61241347", "0.60951066", "0.6052068", "0.6018031", "0.6008414", "0.59951335", "0.5985768", "0.5982042", "0.5973828", "0.595791", "0.5948038", "0.5947677", "0.594654", "0.59456307", "0.59259117", "0.59239286", "0.5900658", "0.5897016", "0.58694506", "0.5852955", "0.5847333", "0.5837847", "0.58006257", "0.5793473", "0.5788364", "0.5760066", "0.57509", "0.57279444", "0.571705", "0.57084584", "0.57083607", "0.56972444", "0.56919974", "0.5685836", "0.5680982", "0.56646967", "0.5652538", "0.56511515", "0.564525" ]
0.0
-1
set the attribute names in the 1st column
public void setPropNames(ArrayList<String> props) { this.prop_names = props; fireTableDataChanged(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void changeAttrName() {\r\n }", "public void setColumnName (String ColumnName);", "protected void setAttributeNames(String[] newColumnNames) {\n\n\t\tadjustAttributeColumnsNumbers(newColumnNames.length);\n\t\tassert attributeColumns.size() == newColumnNames.length;\n\n\t\tif (attributeNamesDefinedByUser()) {\n\t\t\t// assume attributes names were set already by the user\n\t\t\treturn;\n\t\t}\n\t\tList<AttributeColumn> allAttributeColumns = getAllAttributeColumns();\n\t\tString[] oldColumnNames = new String[allAttributeColumns.size()];\n\t\tint i = 0;\n\t\tfor (AttributeColumn column : allAttributeColumns) {\n\t\t\toldColumnNames[i] = column.getName();\n\t\t\ti++;\n\t\t}\n\n\t\tnewColumnNames = getGenericColumnNames(newColumnNames, oldColumnNames);\n\t\ti = 0;\n\t\tfor (AttributeColumn column : allAttributeColumns) {\n\t\t\tcolumn.setName(newColumnNames[i]);\n\t\t\ti++;\n\t\t}\n\t}", "public String getColumnNameOne(){\n return columnNameOneLbl.getText();\n }", "private void setColumnNames() {\r\n columnNames = new String[classFields.length];\r\n for (int i = 0; i < classFields.length; i++) {\r\n columnNames[i] = classFields[i].getName();\r\n }\r\n }", "public void setColumnName(String columnName);", "private void setColumnName(ResultSetMetaData metadata) throws SQLException {\r\n if (connectedToDatabase) {\r\n for (int i = 1; i <= numberOfcolumns; i++) {\r\n columnNames.add(i - 1, metadata.getColumnName(i));\r\n }\r\n /**\r\n * create new column to handle status of row. You can hide or visible it by comment or not the line code follow.\r\n */\r\n //columnNames.add(\"RecordStatus\");\r\n }\r\n }", "protected String getNewGenericColumnName(int column) {\n\t\tHashSet<String> usedNames = new HashSet<>();\n\t\tfor (AttributeColumn col : getAllAttributeColumns()) {\n\t\t\tusedNames.add(col.getName());\n\t\t}\n\n\t\twhile (usedNames.contains(\"attribute_\" + column)) {\n\t\t\tcolumn++;\n\t\t}\n\t\treturn \"attribute_\" + column;\n\t}", "public String getAttributeName() {\n\n if (getAD_Column_ID() == 0) {\n return super.getAttributeName();\n }\n\n // We have a column\n String\tattribute\t= super.getAttributeName();\n\n if ((attribute != null) && (attribute.length() > 0)) {\n return attribute;\n }\n\n setAttributeName(getColumn().getColumnName());\n\n return super.getAttributeName();\n\n }", "private String getAttributeValue() {\n\t\tString attributes = \"\";\r\n\t\tfor(int i=0;i< JTable1.getRowCount();i++ ) {\r\n\t\t\tString attributename = ((String) JTable1.getValueAt(i, 0)).trim();\r\n\t\t\tString attributeValue = ((String) JTable1.getValueAt(i, 1)).trim();\r\n\t\t\t//attributeValue.trim();\r\n\t\t\tif(attributeValue != null && attributeValue.length() > 0)\r\n\t\t\tattributes = attributes.trim() + attributename+ \"=\" + attributeValue + \";\";\r\n\t\t\t\r\n\t\t}\r\n\t\tif(attributes.trim().length() > 0)\r\n\t\treturn attributes.substring(0, attributes.length()-1);\r\n\t\treturn attributes;\r\n\t}", "public void setColumnName(Vector header) {\r\n numberOfcolumns = header.size();\r\n columnNames = header;\r\n /**\r\n * create new column to handle status of row. You can hide or visible it by comment or not the line code follow.\r\n */\r\n //columnNames.add(\"RecordStatus\");\r\n }", "private void appendColumnName() {\n appendColumnNames(joinQueryInputs.columns, true);\n }", "public TableDataColumn(Creation creation){\r\n\t\tsuper();\r\n\t\tthis.creation = creation;\r\n\t\tattributs.add(new AttributDescribe(false, (\"NAME_COLUMN\"+(getRowCount()+1)), \"VARCHAR2\", \"20\", false, false));\r\n\t}", "public AttributeColumn(String attributeName) {\n\t\t\t// default parameters for value type, ... are implicit created\n\t\t\tthis.setName(attributeName);\n\t\t\t// this.setValueType(Ontology.NOMINAL);\n\t\t}", "@Override\r\n public String getColumnName(int col) {\r\n return title[col];\r\n }", "public void setColumnName(String newVal) {\n if ((newVal != null && this.columnName != null && (newVal.compareTo(this.columnName) == 0)) || \n (newVal == null && this.columnName == null && columnName_is_initialized)) {\n return; \n } \n this.columnName = newVal; \n\n columnName_is_modified = true; \n columnName_is_initialized = true; \n }", "String getColumnName();", "@Override\n public String getColumnName(int iCol) {\n return ARR_STR_HEADERS[iCol];\n }", "private static String [] getColumnName(){\r\n\t\tString [] columnNames = { DBSAResourceBundle.res.getString(\"no\"), DBSAResourceBundle.res.getString(\"title\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"authors\"), DBSAResourceBundle.res.getString(\"link\"),\r\n\t\t\t\tDBSAResourceBundle.res.getString(\"year\"),DBSAResourceBundle.res.getString(\"abstract\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"publisher\"),(\"X\"), \r\n\t\t\t\t(\"duplicate\"), \"id\"};\r\n\t\t\t\r\n\t\treturn columnNames;\r\n\t}", "@Override\n public String getColumnName(int column) { return columnnames[column]; }", "@Override\n\tpublic void setAttributeIndices(String value) {\n\t\t\n\t}", "public void setAttr1(String attr1) {\n this.attr1 = attr1;\n }", "public void setAttr1(String attr1) {\n this.attr1 = attr1;\n }", "public static List<String> setColumnNames(){\n List <String> columnName = new ArrayList<>();\n columnName.add(\"Category No\");\n columnName.add(\"Category Name\");\n\n return columnName;\n }", "public String getColumnName();", "public String getAttributeName(){\n if(field.getAnnotation(Column.class) != null){\n return field.getAnnotation(Column.class).column();\n }\n if( field.getAnnotation(PrimaryKey.class) !=null){\n return field.getAnnotation(PrimaryKey.class).name();\n }\n return null;\n }", "public String getElementAttribute(int row, int attr);", "public String getColumnNameThree(){\n return columnNameThreeLbl.getText();\n }", "private void initColumns() {\n columnNames = new LinkedList<String>();\n columnNames.add(\"table.ededb.datatable.action\");\n columnNames.add(\"table.ededb.datatable.filename\");\n columnNames.add(\"table.ededb.datatable.mime\");\n columnNames.add(\"table.ededb.datatable.size\");\n columnNames.add(\"table.ededb.datatable.localcopy\");\n }", "Table setColumn(int index, String name);", "ColumnNames createColumnNames();", "private void buildAttrNamesSet() {\r\n\t\tFileReader file = null;\r\n\t\tString fileName = \"data/attributesType.txt\";\r\n\r\n\t\ttry {\r\n\t\t\tfile = new FileReader(fileName);\r\n\t\t\tBufferedReader reader = new BufferedReader(file);\r\n\t\t\tString line = \"\";\r\n\t\t\twhile ((line = reader.readLine()) != null) {\r\n\t\t\t\tString strLine[] = line.split(\" \");\r\n\t\t\t\tint type = Integer.parseInt(strLine[1]);\r\n\t\t\t\thmAttrNames.put(strLine[0], new Integer(type));\r\n\t\t\t}\r\n\r\n\t\t\tfile.close();\r\n\r\n\t\t} catch (FileNotFoundException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (NumberFormatException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t\t/*\r\n\t\t * // Get a set of the entries Set set = hmAttrNames.entrySet(); // Get\r\n\t\t * an iterator Iterator i = set.iterator(); // Display elements while\r\n\t\t * (i.hasNext()) { Map.Entry me = (Map.Entry) i.next();\r\n\t\t * System.out.print(me.getKey() + \": \");\r\n\t\t * System.out.println(me.getValue()); } System.out.println();\r\n\t\t */\r\n\t}", "public String getColumnNameTwo(){\n return columnNameTwoLbl.getText();\n }", "@Test\n public void testSetColumnName() {\n writeBanner(getMethodName());\n }", "com.microsoft.schemas.xrm._2013.metadata.AttributeTypeDisplayName addNewAttributeTypeDisplayName();", "public String getAttributeName() {\n/* 85 */ return this.attributeName;\n/* */ }", "protected abstract String getFavoriteColumnName();", "private static String [] getColumnName(){\r\n\t\tString [] columnNames = { DBSAResourceBundle.res.getString(\"no\"), DBSAResourceBundle.res.getString(\"title\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"authors\"), DBSAResourceBundle.res.getString(\"link\"),\r\n\t\t\t\tDBSAResourceBundle.res.getString(\"year\"),DBSAResourceBundle.res.getString(\"abstract\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"publisher\"),DBSAResourceBundle.res.getString(\"mark\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"duplicate\"), \"dlsName\"};\r\n\t\t\t\r\n\t\treturn columnNames;\r\n\t}", "private String getAllColumnName() {\n\t\t\n\t\tStringBuilder builder = new StringBuilder();\n\t\t// .append(COLUMN_id).append(\"=?,\").\n\t\tbuilder.append(\"user_id\").append(\"=?,\");\n\t\tbuilder.append(\"lib_book_id\").append(\"=?,\");\n\t\tbuilder.append(\"lending_date\").append(\"=?,\");\n\t\tbuilder.append(\"return_date\").append(\"=?,\");\n\t\tbuilder.append(\"returned_date\").append(\"=?,\");\n\t\tbuilder.append(\"status\").append(\"=?\");\n\t\t\n\t\treturn builder.toString();\n\t}", "AttributeCell createAttributeCell();", "@Override\n public String getColumnName(int column) {\n if (column == COL_ID) {\n return \"Código\";\n } else if (column == COL_NAME) {\n return \"Nome\";\n }\n return \"\";\n }", "@Override\n public String getName() {\n return columnInfo.getName();\n }", "@Override\n\tpublic Identifier determineBasicColumnName(ImplicitBasicColumnNameSource source) {\n\t\treturn toIdentifier( transformAttributePath( source.getAttributePath() ), source.getBuildingContext() );\n\t}", "@Override\n\tpublic String[] getFieldName() {\n\t\treturn new String[]{\"编码\",\"名称\",\"属性\"};\n\t}", "@Override\n public String getColumnName(int aColumn) {\n return model.getColumnName(aColumn); \n }", "@Override\n public void alterColumnByName(String name, XPropertySet descriptor) throws SQLException, NoSuchElementException {\n \n }", "public void updateAttributeName()\n\t{\n\t\tString layerName = mCartogramWizard.getCartogramLayerName();\n\t\t\n\t\tif (mCurrentCartogramLayer != layerName)\n\t\t{\n\t\t\t\n\t\t\t// Change the layer name attribute.\n\t\t\tmCurrentCartogramLayer = layerName;\n\n\n\t\t\t// Remove all existing items.\n\t\t\tmAttributeMenu.removeAllItems();\n\t\t\t\n\n\t\t\t// Get the numerical attributes of the current cartogram layer.\n\t\t\tif (mCurrentCartogramLayer != null &&\n\t\t\t\tmCurrentCartogramLayer != \"\" &&\n\t\t\t\tmCurrentCartogramLayer != \"<none>\")\n\t\t\t{\n\t\t\n\t\t\t\tLayer lyr = AppContext.layerManager.getLayer(\n\t\t\t\t\t\t\t\tmCurrentCartogramLayer);\n\t\t\t\n\t\t\t\tFeatureSchema fs = \n\t\t\t\t\tlyr.getFeatureCollectionWrapper().getFeatureSchema();\n\t\t\t\n\t\t\t\tint nattrs = fs.getAttributeCount();\n\t\t\t\n\t\t\t\tfor (int attrcnt = 0; attrcnt < nattrs; attrcnt++)\n\t\t\t\t{\n\t\t\t\t\n\t\t\t\t\tAttributeType attrtype = fs.getAttributeType(attrcnt);\n\t\t\t\t\tif (attrtype == AttributeType.DOUBLE ||\n\t\t\t\t\t\tattrtype == AttributeType.INTEGER)\n\t\t\t\t\t{\n\t\t\t\t\t\tmAttributeMenu.addItem(fs.getAttributeName(attrcnt));\n\t\t\t\t\t}\n\t\t\t\t\n\t\t\t\t}\n\t\t\t\n\t\t\t}\n\t\t\n\t\t\n\t\t\t// If there is no attribute we can select,\n\t\t\t// add an item \"<none>\" and disable the \"Next\" button.\n\t\t\tif (mAttributeMenu.getItemCount() == 0)\n\t\t\t{\n\t\t\t\tmAttributeMenu.addItem(\"<none>\");\n\t\t\t\tmNextButton.setEnabled(false);\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tmNextButton.setEnabled(true);\n\t\t\t}\n\t\t\t\n\t\t\t\t\n\t\t}\n\t\n\t}", "@Override\n public String getColumnName(int column) {\n return columnNames[column];\n }", "@Override\n public String getColumnName(int column) {\n return columnNames[column];\n }", "public void setAttributes(TableAttributes attrs) {\n\tthis.attrs = attrs;\n }", "List<String> get_attribute_name(String table) {\n //table does not exist\n if (!get_table_names().contains(table) && !table.equals(\"relationship\")) {\n throw new RuntimeException(\"Table does not exist.\");\n }\n\n LinkedList<String> res = new LinkedList<>();\n\n String sql = \"select * from \" + table;\n\n ResultSet resultSet = execute_statement(sql, true); //get all data records\n try {\n ResultSetMetaData rsmd = resultSet.getMetaData();\n int column_cnt = rsmd.getColumnCount();\n for (int i=2; i <= column_cnt; i++) {\n res.add(rsmd.getColumnName(i)); //add column name\n }\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n try {\n this.disconnect(resultSet, null, null); //disconnect from database\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n return res;\n }", "@Override\n public String getColumnName(int column) {\n return colName[column];\n }", "@Override\n\tpublic void setAttribute(String arg0, Object arg1) {\n\n\t}", "@Override\n\tpublic String getColumnName(int column) {\n\t\treturn names[column];\n\t}", "public String getColumnone() {\n return columnone;\n }", "@Override\r\n\tpublic String getColumnName(int column) {\n\t\treturn columnName[column];\r\n\t}", "@Override\r\n\tpublic String getColumnName(int column) {\n\t\treturn columnName[column];\r\n\t}", "@Override\n public String getColumnName(int columnIndex) {\n return nomeColunas[columnIndex];\n }", "@Override\n public String getColumnName(int columnIndex) {\n return nomeColunas[columnIndex];\n }", "public Object[] getColumnNames(){\r\n if (ufeRunner == null || renders == null || htmlObjLang == null) {\r\n return null;\r\n }\r\n String[] columnNames = {\"Name\", \"Value\"};\r\n return columnNames;\r\n }", "public String getAttr1() {\n return attr1;\n }", "public String getAttr1() {\n return attr1;\n }", "@Override\n\tpublic void setName(java.lang.String name) {\n\t\t_expandoColumn.setName(name);\n\t}", "@Override\n\tpublic String getColumnName(int col) {\n\t\treturn NOMICOLONNE[col];\n\t}", "public Map<String, Object> attributes() {\n Map<String, Object> attributes = new HashMap<String, Object>();\n for (Column column : getColumns()) {\n String name = Strings.camelize(column.getName(), true);\n attributes.put(name, attribute(name));\n }\n return attributes;\n }", "public void setEmphcolumn(String emphColumnIn)\n {\n emphColumn = emphColumnIn;\n }", "private void adjustAttributeColumnsNumbers(int newNumberOfColumns) {\n\t\t// too short\n\t\tif (getAllAttributeColumns().size() < newNumberOfColumns) {\n\t\t\tint actualNumberOfAttributes = getAllAttributeColumns().size();\n\t\t\tint numberOfNewColumns = newNumberOfColumns - actualNumberOfAttributes;\n\t\t\tString[] genericNames = new String[numberOfNewColumns];\n\t\t\tfor (int i = 0; i < numberOfNewColumns; i++) {\n\t\t\t\tgenericNames[i] = getNewGenericColumnName(actualNumberOfAttributes + i);\n\t\t\t}\n\t\t\tfor (String name : genericNames) {\n\t\t\t\tattributeColumns.add(new AttributeColumn(name));\n\t\t\t}\n\n\t\t}\n\t\t// too long\n\t\tif (getAllAttributeColumns().size() > newNumberOfColumns) {\n\t\t\tList<AttributeColumn> list = new ArrayList<>();\n\t\t\tfor (int i = 0; i < newNumberOfColumns; i++) {\n\t\t\t\tlist.add(getAttributeColumn(i));\n\t\t\t}\n\t\t\tattributeColumns = list;\n\t\t}\n\t}", "public InputNameForColumnTag()\r\n {\r\n super();\r\n }", "public String getName(){\n\t\t\treturn columnName;\n\t\t}", "private void processBeanAttribute (BeanAttribute attribute) {\n\t\t// HACK TO GET RID OF UNSIGNED FROM MYSQL DEFINITIONS\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\tif (attribute.getColumnType() != null && !attribute.getColumnType().isEmpty()) {\r\n\t\t\tattribute.setColumnType(GenerateBeanUtils.removeUnsigned(attribute.getColumnType()));\r\n\t\t}\r\n\t\t\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t// Use the Name as the Java attribute name - this is the master.\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\r\n\t\tif (attribute.getName() == null || attribute.getName().trim().isEmpty()) {\r\n\t\t\t// No Java Name given - create a name from the Column Name:\r\n\t\t\t\r\n\t\t\tif (attribute.getColumnName() != null && !attribute.getColumnName().trim().isEmpty()) {\r\n\t\t\t\tif (StringUtils.isAllUpperCase(attribute.getColumnName())) {\r\n\t\t\t\t\tattribute.setName(attribute.getColumnName().toLowerCase());\r\n\t\t\t\t} else {\r\n\t\t\t\t\tattribute.setName(StringUtils.uncapitalize(attribute.getColumnName()));\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t} else {\r\n\t\t\t\tlogger.error(\"An attribute has been passed without a column name or a java name - something has gone wrong!!!!\");\r\n\t\t\t}\r\n\t\t\t\r\n\t\t} else {\r\n\t\t\t// Give the Java name sensible options\r\n\t\t\tif (StringUtils.isAllUpperCase(attribute.getName())) {\r\n\t\t\t\tattribute.setName(attribute.getName().toLowerCase());\r\n\t\t\t}\r\n\t\t}\r\n\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t// If the column name has not been set - create a name based on the Java name\r\n\t\t// -------------------------------------------------------------------------------\r\n\r\n\t\tif (attribute.getColumnName() == null || attribute.getColumnName().trim().isEmpty()) {\r\n\t\t\t// No Column Name given - create a name from the Java Name:\r\n\t\t\tattribute.setColumnName(StringUtils.capitalize(attribute.getName()));\r\n\t\t}\r\n\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t// If the java type has not been set - generate one from the column type \r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t\r\n\t\t// should check if the type is valid!\r\n\t\tif (attribute.getType()==null || attribute.getType().isEmpty()) {\t\t\t\t\t\r\n\t\t\tattribute.setType(GenerateBeanUtils.convertColumnTypeToJavaType(attribute.getColumnType()));\t\t\t\t\t\r\n\t\t} \r\n\t\t\r\n\t\t// Deal with issue of time stamps.\r\n\t\tif (attribute.getType().toLowerCase().equals(\"timestamp\")) {\r\n\t\t\tattribute.setType(\"Date\");\r\n\t\t}\r\n\t\t\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t// If the column type has not been set - generate one from the java type \r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t\r\n\t\t// should check if the type is valid!\r\n\t\tif (attribute.getColumnType()==null || attribute.getColumnType().isEmpty()) {\t\t\t\t\t\r\n\t\t\tattribute.setColumnType(GenerateBeanUtils.convertJavaTypeToColumnType(attribute.getType()));\t\t\t\t\t\r\n\t\t} \r\n\t\t\r\n\t\t// check to see if this is a varchar - need to set the max size.\r\n\t\tif (attribute.getColumnType().toLowerCase().equals(\"varchar\") ) {\r\n\t\t\tif (attribute.getColumnSize() < 1) {\r\n\t\t\t\tif(attribute.getMaxValue() < 1) {\r\n\t\t\t\t\tattribute.setColumnSize(255);\t\t\t\t\t\t\r\n\t\t\t\t} else {\r\n\t\t\t\t\tattribute.setColumnSize(attribute.getMaxValue());\t\t\t\t\t\t\t\t\t\t\t\t\t\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\t\r\n\t\t\t// Set the validation max size to column size\r\n\t\t\tif (attribute.getMaxValue() < 1 ) {\r\n\t\t\t\tattribute.setMaxValue(attribute.getColumnSize());\r\n\t\t\t}\t\t\t\t\t\r\n\t\t}\r\n\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t// Helpers\r\n\t\t// -------------------------------------------------------------------------------\r\n\t\t\r\n\t\tattribute.setObject(GenerateBeanUtils.isObject(attribute.getType()));\t\t\t\t\r\n\r\n\t\t// Check to see if a regular expression has been set and if it is valid...\r\n\t\tif (attribute.getValidationRegExp()!= null && !attribute.getValidationRegExp().trim().isEmpty()) { \r\n\t\t\t\tString result = GenerateBeanUtils.validateRegularExpression(attribute.getValidationRegExp());\r\n\t\t\t\tattribute.setValidationRegExp(result);\r\n\t\t\t\t\r\n\t\t\t\tif (result == null) {\r\n\t\t\t\t\tlogger.warn(\"Error parsing supplied regular expression - ignoring\"); \r\n\t\t\t\t}\r\n\t\t\t\tattribute.setValidationRegExp(result);\r\n\t\t}\r\n\t\t\r\n\t\tattribute.setValidated(GenerateBeanUtils.isValidated(attribute.getValidationRegExp(), attribute.getMinValue(), attribute.getMaxValue(),attribute.isMandatory()));\r\n\t\t\r\n\t\tlogger.trace(attribute);\r\n\r\n\t\t\r\n\t}", "String attributeToSetter(String name);", "@Override\n\tpublic void setAttribute(String arg0, Object arg1, int arg2) {\n\n\t}", "public void setLabelColumn(String labelColumn)\n {\n myLabelColumn = labelColumn;\n }", "public String getAttribute1() {\n return attribute1;\n }", "@Override\n\tpublic String getColumnName(int column) {\n\t\tswitch (column) {\n\t\tcase 0:\n\t\t\treturn \"Expression\";\n\t\tcase 1:\n\t\t\treturn \"Value\";\n\t\t}\n\t\treturn null;\n\t}", "public String getColumnName() {\n return columnName; \n }", "@Override\n public int getColumnCount() { return columnnames.length; }", "private void getColumnNames() {\n try {\n String qry1 = \"select * from \" + StaticData.tablename;\n ResultSet rs = EstablishConnection.executeQuery(qry1);\n rsmd = rs.getMetaData();\n int columnCount = rsmd.getColumnCount();\n DefaultListModel dlm=new DefaultListModel();\n for (int i = 1; i <= columnCount; i++) {\n StaticData.columntype[i]=rsmd.getColumnTypeName(i);\n dlm.addElement(rsmd.getColumnName(i));\n String value = rsmd.getColumnName(i);\n jComboBox_columnNames.addItem(value);\n }\n //dlm.addElement(\"ALL\");\n jList_columnNames.setModel(dlm);\n JScrollPane jsp = new JScrollPane(list);\n } catch (SQLException ex) {\n Logger.getLogger(ConditionFrame.class.getName()).log(Level.SEVERE, null, ex);\n }\n }", "public void setColumnName(String columnName)\n {\n this.columnName = columnName;\n }", "default List<String> getPrimaryAttributeNames() {\n\t\treturn getPrimaryAttributes().stream().map(attr -> attr.getName()).collect(Collectors.toList());\n\t}", "private static void setData() {\n attributeDisplaySeq = new ArrayList<String>();\n attributeDisplaySeq.add(\"email\");\n\n signUpFieldsC2O = new HashMap<String, String>();\n signUpFieldsC2O.put(\"Email\",\"email\");\n\n\n signUpFieldsO2C = new HashMap<String, String>();\n signUpFieldsO2C.put(\"email\", \"Email\");\n\n\n }", "public void setNameIndex(int index);", "public String getCol1species() {\n return col1species;\n }", "public String getCol1() {\n\t\treturn col1;\n\t}", "@Override\n\t\tpublic void addAttribute(String name, String value) {\n\t\t\t\n\t\t}", "@Override\n\t\tpublic void addAttribute(String name, String value) {\n\t\t\t\n\t\t}", "@Override\n public String getColumnName(int column) {\n return cabecera[column];\n }", "public void setColumnName(java.lang.String columnName) {\r\n this.columnName = columnName;\r\n }", "public void setColumnName(String columnName) {\n this.columnName = columnName;\n }", "public void setColumninfo(String[] headerArray) {\r\n\t\tthis.headerRow = headerArray;\r\n\t}", "public void setColumns(List<String> columnNames);", "public void setAD_Column_ID (int AD_Column_ID);", "public void setAttribute(NameValue a) {\n\t\tattribute = a;\n\t\tattribute.setSeparator(Separators.COLON);\n\t}", "@Override\n\tpublic String getColumnName(int col)\n\t{\n\t\treturn nomColonnes[col];\n\t}", "SqlColumns(String columnName){\n\t\t\t this.columnName = columnName; \n\t\t}", "java.lang.String getColumn();", "public void setColumnName(String columnName) {\r\n navBinder.setColumnName(columnName);\r\n }", "public String getName() {\n return columnName;\n }", "@Override\n\t\t\tpublic ColumnMetaData getColumnMetaData() {\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tthrow new UnsupportedOperationException(\n\t\t\t\t\t\t\"If you want to use val() to create a real\"\n\t\t\t\t\t\t\t\t+ \" column within a tuple, give it a name (i.e. use val(obj, name))!\");\n\t\t\t}", "protected void setupDBColumns() \n\t{\n\t\tthis.dbColumnNames = new Vector<String>();\n\t\tthis.dbColumnNames.addElement(\"ID\");\n\t}", "public String getColumnName() {\n return this.columnName;\n }" ]
[ "0.6606308", "0.6402141", "0.63941175", "0.63040805", "0.6177223", "0.6170239", "0.6125693", "0.60973674", "0.60854423", "0.6008991", "0.6000492", "0.59830856", "0.593816", "0.593626", "0.59276533", "0.5917722", "0.58757246", "0.58550143", "0.5835047", "0.58228385", "0.5808464", "0.5790078", "0.5790078", "0.5777058", "0.57557076", "0.57548064", "0.57416505", "0.57378685", "0.5731704", "0.5724407", "0.5719686", "0.57147944", "0.569924", "0.5699061", "0.5651118", "0.56510484", "0.56388015", "0.56385124", "0.56143403", "0.56113297", "0.56104887", "0.55966437", "0.5594089", "0.5590749", "0.5584652", "0.55800897", "0.5572457", "0.5570946", "0.5570946", "0.5552236", "0.55423224", "0.55374825", "0.5518075", "0.5510269", "0.5509195", "0.55089015", "0.55089015", "0.55069107", "0.55069107", "0.5502009", "0.5477901", "0.5477901", "0.5468162", "0.5459361", "0.5452187", "0.54517454", "0.54472286", "0.543442", "0.54326254", "0.54311365", "0.54220366", "0.5417461", "0.5408075", "0.5402059", "0.54013383", "0.53923327", "0.5392121", "0.53918034", "0.53866184", "0.53835213", "0.5383168", "0.5378967", "0.5378424", "0.53743136", "0.53640026", "0.53640026", "0.5362786", "0.5360055", "0.53597945", "0.53565073", "0.53484386", "0.534469", "0.53407925", "0.5337097", "0.53364164", "0.5335839", "0.5331351", "0.53290564", "0.53246504", "0.53208697", "0.53186715" ]
0.0
-1
get the attribute name list in the 1st column
public ArrayList<String> getPropNames() { return this.prop_names; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public List getAttributeNames() {\n log.debug(\"getAttributeNames()\");\n ResultSet resultSet = attrNST.selectRows(\"name\");\n return resultSet.toStringList(1);\n }", "List<String> get_attribute_name(String table) {\n //table does not exist\n if (!get_table_names().contains(table) && !table.equals(\"relationship\")) {\n throw new RuntimeException(\"Table does not exist.\");\n }\n\n LinkedList<String> res = new LinkedList<>();\n\n String sql = \"select * from \" + table;\n\n ResultSet resultSet = execute_statement(sql, true); //get all data records\n try {\n ResultSetMetaData rsmd = resultSet.getMetaData();\n int column_cnt = rsmd.getColumnCount();\n for (int i=2; i <= column_cnt; i++) {\n res.add(rsmd.getColumnName(i)); //add column name\n }\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n try {\n this.disconnect(resultSet, null, null); //disconnect from database\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n return res;\n }", "public String [] getNames () { \n return this.listAttributes(); \n }", "default List<String> getPrimaryAttributeNames() {\n\t\treturn getPrimaryAttributes().stream().map(attr -> attr.getName()).collect(Collectors.toList());\n\t}", "private String getAttributeValue() {\n\t\tString attributes = \"\";\r\n\t\tfor(int i=0;i< JTable1.getRowCount();i++ ) {\r\n\t\t\tString attributename = ((String) JTable1.getValueAt(i, 0)).trim();\r\n\t\t\tString attributeValue = ((String) JTable1.getValueAt(i, 1)).trim();\r\n\t\t\t//attributeValue.trim();\r\n\t\t\tif(attributeValue != null && attributeValue.length() > 0)\r\n\t\t\tattributes = attributes.trim() + attributename+ \"=\" + attributeValue + \";\";\r\n\t\t\t\r\n\t\t}\r\n\t\tif(attributes.trim().length() > 0)\r\n\t\treturn attributes.substring(0, attributes.length()-1);\r\n\t\treturn attributes;\r\n\t}", "public ArrayList<String> getAttributeNames(String table) throws QueryFailedException {\n String query = String.format(\"SELECT COLUMN_NAME FROM information_schema.Columns WHERE TABLE_NAME = '%s' AND TABLE_SCHEMA = '%s'\", table, database.getDatabaseName());\n try {\n ResultSet rs = this.execute(query);\n ArrayList<String> attributeNames = new ArrayList<String>();\n while(rs.next()) {\n attributeNames.add(rs.getString(\"COLUMN_NAME\"));\n }\n return attributeNames;\n } catch (QueryFailedException | SQLException e) {\n e.printStackTrace();\n throw new QueryFailedException(\"Failed getting attribute names\");\n }\n }", "default List<String> getAttributeNames() {\n\t\treturn getAttributes().stream().map(v -> v.getName()).collect(Collectors.toList());\n\t}", "public List<String> getAttributeNames(String tableName) {\r\n\tArrayList<String> result = new ArrayList<String>();\r\n\r\n\tStatement stat = null;\r\n\tResultSet rs = null;\r\n\r\n\ttry {\r\n\t stat = conn.createStatement();\r\n\r\n\t rs = stat.executeQuery(\"PRAGMA table_info('\" + tableName + \"');\");\r\n\r\n\t while (rs.next()) {\r\n\t\tString attributeName = rs.getString(\"name\");\r\n\r\n\t\tif (attributeName != null && attributeName.length() > 0) {\r\n\t\t result.add(attributeName);\r\n\t\t}\r\n\t }\r\n\r\n\t} catch (Exception e) {\r\n\t System.out.print(StackTraceUtil.toString(e));\r\n\t} finally {\r\n\t Cleanup(stat, rs);\r\n\t}\r\n\r\n\treturn result;\r\n }", "public Set<String> getAttributeNames();", "public abstract String[] getRequiredAttributeNames();", "ArrayList getAttributes();", "public ArrayList<String> getColumnNames();", "private static String [] getColumnName(){\r\n\t\tString [] columnNames = { DBSAResourceBundle.res.getString(\"no\"), DBSAResourceBundle.res.getString(\"title\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"authors\"), DBSAResourceBundle.res.getString(\"link\"),\r\n\t\t\t\tDBSAResourceBundle.res.getString(\"year\"),DBSAResourceBundle.res.getString(\"abstract\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"publisher\"),DBSAResourceBundle.res.getString(\"mark\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"duplicate\"), \"dlsName\"};\r\n\t\t\t\r\n\t\treturn columnNames;\r\n\t}", "List<String> getColumns();", "public String getColumnNameOne(){\n return columnNameOneLbl.getText();\n }", "private static String [] getColumnName(){\r\n\t\tString [] columnNames = { DBSAResourceBundle.res.getString(\"no\"), DBSAResourceBundle.res.getString(\"title\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"authors\"), DBSAResourceBundle.res.getString(\"link\"),\r\n\t\t\t\tDBSAResourceBundle.res.getString(\"year\"),DBSAResourceBundle.res.getString(\"abstract\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"publisher\"),(\"X\"), \r\n\t\t\t\t(\"duplicate\"), \"id\"};\r\n\t\t\t\r\n\t\treturn columnNames;\r\n\t}", "private ArrayList<String> getJoinedAttributeNames(List<Table> tables) {\n\t\tArrayList<String> rtn = new ArrayList<String>(); \n\n\t\ttry {\n\t\t\tfor(int iterator = 0; iterator < tables.size(); iterator++) {\n\t\t\t\tTable table = tables.get(iterator);\n\t\t\t\tFile root = new File(\"src\");\n\t\t\t\tURLClassLoader classLoader = URLClassLoader.newInstance(new URL[] { root.toURI().toURL() });\n\t\t\t\tClass<?> cl = Class.forName(table.getName(), true, classLoader);\n\t\t\t\t\n\t\t\t\tField fields[] = cl.getDeclaredFields();\n\t\t\t\tfor(int i = 0; i < fields.length; i++) {\n\t\t\t\t\tField field = fields[i];\n\t\t\t\t\tfield.setAccessible(true);\n\t\t\t\t\trtn.add(field.getName());\n\t\t\t\t\tfield.setAccessible(false);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tcatch (ClassNotFoundException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\tcatch (MalformedURLException e)\t{\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t\treturn rtn;\n\t}", "public List<String> getAttributeNames() {\n\t\treturn new ArrayList<>(attributes.keySet());\n\t}", "public List<String> getColumns();", "@Override\n\tpublic ArrayList<Object> getAttributeList() {\n\t\tArrayList<Object> attributes = new ArrayList<Object>();\n//\t\tattributes.add(\"s2014_age\");\n//\t\tattributes.add(\"s2014_prog_skill\");\n//\t\tattributes.add(\"s2014_uni_yrs\");\n//\t\tattributes.add(\"s2014_os\");\n//\t\tattributes.add(\"s2014_progLangs\");\n//\t\tattributes.add(\"s2014_engSkill\");\n\t\tattributes.add(\"s2014_favAnimal\");\n\t\tattributes.add(\"s2014_MoreMtns\");\n//\t\tattributes.add(\"s2014_winter\");\n\t\tattributes.add(\"s2014_favColor\");\n//\t\tattributes.add(\"s2014_neuralNetwork\");\n//\t\tattributes.add(\"s2014_vectorMachine\");\n//\t\tattributes.add(\"s2014_sql\");\n//\t\tattributes.add(\"s2014_favSQLServ\");\n//\t\tattributes.add(\"s2014_apriori\");\n\t\treturn attributes;\n\t}", "public String[] getAttributeNames()\n {\n String superNames[] = super.getAttributeNames();\n\n if (localfs.isUnixFS())\n {\n StringList list = new StringList(superNames);\n list.add(LocalFSFactory.unixFSAttributeNames);\n return list.toArray();\n }\n\n return superNames;\n }", "public String[] getColumnNames(T1 ob) {\n\t\tjava.lang.reflect.Field[] f1=ob.getClass().getDeclaredFields(); \r\n\t\tString[] s =new String[f1.length-1];\t\r\n\t\t//JOptionPane.showMessageDialog(null,f1.length); \r\n\t\tfor(int i=0;i<f1.length-1;i++)\r\n\t\t{\r\n\t\t\t String name = f1[i].getName(); //获取属性的名字\r\n\t\t\t String type = f1[i].getGenericType().toString(); //获取属性的类型\r\n\t if(type.equals(\"class java.lang.String\")){ //如果type是类类型,则前面包含\"class \",后面跟类名\r\n\t\t name=name.substring(0, 1).toUpperCase()+name.substring(1);\r\n\t\t //JOptionPane.showMessageDialog(null,name);\r\n\t\t Method m = null;\r\n\t\t\ttry {\r\n\t\t\t\tm = ob.getClass().getMethod(\"get\"+name);\r\n\t\t\t} catch (SecurityException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (NoSuchMethodException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t}\r\n\t String value = null;\r\n\t\t\ttry {\r\n\t\t\t\tvalue = (String) m.invoke(ob);\r\n\t\t\t} catch (IllegalArgumentException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (IllegalAccessException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (InvocationTargetException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} //调用getter方法获取属性值\r\n\t if(value != null){\t \r\n\t s[i]=value;\r\n\t\t\t\t //JOptionPane.showMessageDialog(null,value);\r\n\t }\r\n\t\t\t\t\r\n\t\t\t}\t\r\n\t\t }\r\n\t\t//JOptionPane.showMessageDialog(null,s.size());\r\n\t return s;\r\n\t\t\r\n }", "public String[] getAttributeNames()\n {\n return attributeNames;\n }", "public String getAttributeName() {\n\n if (getAD_Column_ID() == 0) {\n return super.getAttributeName();\n }\n\n // We have a column\n String\tattribute\t= super.getAttributeName();\n\n if ((attribute != null) && (attribute.length() > 0)) {\n return attribute;\n }\n\n setAttributeName(getColumn().getColumnName());\n\n return super.getAttributeName();\n\n }", "public Object[] getColumnNames(){\r\n if (ufeRunner == null || renders == null || htmlObjLang == null) {\r\n return null;\r\n }\r\n String[] columnNames = {\"Name\", \"Value\"};\r\n return columnNames;\r\n }", "private String getAllColumnName() {\n\t\t\n\t\tStringBuilder builder = new StringBuilder();\n\t\t// .append(COLUMN_id).append(\"=?,\").\n\t\tbuilder.append(\"user_id\").append(\"=?,\");\n\t\tbuilder.append(\"lib_book_id\").append(\"=?,\");\n\t\tbuilder.append(\"lending_date\").append(\"=?,\");\n\t\tbuilder.append(\"return_date\").append(\"=?,\");\n\t\tbuilder.append(\"returned_date\").append(\"=?,\");\n\t\tbuilder.append(\"status\").append(\"=?\");\n\t\t\n\t\treturn builder.toString();\n\t}", "String getAttributeName(Object attr);", "Object[] getAttributes() throws SQLException;", "java.util.List<tendermint.abci.EventAttribute> \n getAttributesList();", "public String getAttributeName(){\n if(field.getAnnotation(Column.class) != null){\n return field.getAnnotation(Column.class).column();\n }\n if( field.getAnnotation(PrimaryKey.class) !=null){\n return field.getAnnotation(PrimaryKey.class).name();\n }\n return null;\n }", "public String getAttributeName() {\n/* 85 */ return this.attributeName;\n/* */ }", "@Override\r\n\tpublic String[] getAttributeNames() {\n\t\treturn null;\r\n\t}", "@Override\n\t\tpublic Set<String> getAttributeNames() {\n\t\t\treturn null;\n\t\t}", "public List<TLAttribute> getAttributes();", "java.lang.String getAttribute();", "public abstract List<String> getPreFacesRequestAttrNames();", "public java.util.Collection getAttributes();", "@Override\n\tpublic String[] getAttrNames() {\n\t\treturn null;\n\t}", "public String getColumnNameThree(){\n return columnNameThreeLbl.getText();\n }", "public Vector getSampleAnnotationFieldNames();", "protected ArrayList<String> getColumnNames() {\n return getVariableNames();\n }", "public String[] getColumnNames();", "public String[] getRelevantAttributes();", "@Override\n\t\tpublic Enumeration getAttributeNames() {\n\t\t\treturn null;\n\t\t}", "public String getElementAttribute(int row, int attr);", "public static String[] getAttributeNames()\n\t{\n\t\tList<String> attributeNames = new ArrayList<String>();\n\t\tfor ( PwdPolicy attr : PwdPolicy.values() )\n\t\t{\n\t\t\tattributeNames.add( attr.getAttribute() );\n\t\t}\n\t\tString[] result = attributeNames.toArray( new String[attributeNames.size()] );\n\t\tlogger.log( loglevel, \"Returning attribute names: \"+Arrays.toString(result) );\n\t\treturn result;\n\t}", "public Enumeration getAttributes()\n {\n ensureLoaded();\n return m_tblAttribute.elements();\n }", "public List<String> getRecipeName()\n {\n SQLiteDatabase db = getReadableDatabase();\n SQLiteQueryBuilder qb = new SQLiteQueryBuilder();\n\n //Attributes as they appear in the database\n String[] sqlSelect = {\"name\"};\n String RECIPE_TABLE = \"Recipe\"; //Table name as it is in database\n\n qb.setTables(RECIPE_TABLE);\n Cursor cursor = qb.query(db,sqlSelect, null,null, null, null, null);\n List<String> result = new ArrayList<>();\n if(cursor.moveToFirst())\n {\n do{\n result.add(cursor.getString(cursor.getColumnIndex(\"name\")));\n }while(cursor.moveToNext());\n }\n return result;\n }", "public String getStringAttribute();", "public String getColumnNameTwo(){\n return columnNameTwoLbl.getText();\n }", "private String getDataAttributes() {\n StringBuilder sb = new StringBuilder();\n\n dataAttribute.forEach((key, value) -> {\n sb.append(key).append(\"='\").append(value).append(\"' \");\n });\n\n return sb.toString().trim();\n }", "String getColumnName();", "public String getAttribute1() {\n return attribute1;\n }", "@Override\n public String getColumnName(int column) { return columnnames[column]; }", "public static List<String> setColumnNames(){\n List <String> columnName = new ArrayList<>();\n columnName.add(\"Category No\");\n columnName.add(\"Category Name\");\n\n return columnName;\n }", "private List<String> getColNames() {\r\n\t\t//\r\n\t\tDBManager dbm = new DBManager(this);\r\n\t\t\r\n\t\tSQLiteDatabase wdb = dbm.getWritableDatabase();\r\n\r\n\t\t// REF=> http://stackoverflow.com/questions/947215/how-to-get-a-list-of-column-names-on-sqlite3-iphone\r\n\t\tString sql = \"PRAGMA table_info('\" + DBManager.tableName + \"')\";\r\n\t\t\r\n\t\tCursor c = wdb.rawQuery(sql, null);\r\n\t\t\r\n\t\t// Log\r\n\t\tLog.d(\"DBAdminActivity.java\" + \"[\"\r\n\t\t\t\t+ Thread.currentThread().getStackTrace()[2].getLineNumber()\r\n\t\t\t\t+ \"]\", \"c.getCount() => \" + c.getCount());\r\n\t\t\r\n\t\tLog.d(\"DBAdminActivity.java\" + \"[\"\r\n\t\t\t\t+ Thread.currentThread().getStackTrace()[2].getLineNumber()\r\n\t\t\t\t+ \"]\", \"c.getColumnCount() => \" + c.getColumnCount());\r\n\r\n\t\tList<String> colNames = new ArrayList<String>();\r\n\t\t\r\n\t\tc.moveToFirst();\r\n\t\t\r\n\t\tfor (int i = 0; i < c.getCount(); i++) {\r\n\t\t\t\r\n\t\t\tcolNames.add(c.getString(0));\r\n\t\t\t\r\n\t\t\t// Log\r\n\t\t\tLog.d(\"DBAdminActivity.java\" + \"[\"\r\n\t\t\t\t\t+ Thread.currentThread().getStackTrace()[2].getLineNumber()\r\n\t\t\t\t\t+ \"]\", \"c.getString(0) => \" + c.getString(0) + \r\n\t\t\t\t\t\" / \" + \"c.getString(1) => \" + c.getString(1));\r\n\t\t\t\r\n\t\t\t\r\n\t\t\tc.moveToNext();\r\n\t\t\t\r\n\t\t}//for (int i = 0; i < c.getCount(); i++)\r\n\t\t\r\n\t\twdb.close();\r\n\t\t\r\n\t\tfor (String string : colNames) {\r\n\t\t\t\r\n\t\t\t// Log\r\n\t\t\tLog.d(\"DBAdminActivity.java\" + \"[\"\r\n\t\t\t\t\t+ Thread.currentThread().getStackTrace()[2].getLineNumber()\r\n\t\t\t\t\t+ \"]\", \"colName => \" + string);\r\n\t\t\t\r\n\t\t\t\r\n\t\t}\r\n\t\t\r\n//\t\treturn (String[])colNames.toArray();\r\n\t\treturn colNames;\r\n\t\t\r\n\t}", "public String getAttribute1()\n {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "private String getCustomAttributes() {\n StringBuilder sb = new StringBuilder();\n\n customAttribute.forEach((key, value) -> {\n sb.append(key).append(\"='\").append(value).append(\"' \");\n });\n\n return sb.toString().trim();\n }", "public String[] getFieldNames();", "tendermint.abci.EventAttribute getAttributes(int index);", "public Map<String, Object> attributes() {\n Map<String, Object> attributes = new HashMap<String, Object>();\n for (Column column : getColumns()) {\n String name = Strings.camelize(column.getName(), true);\n attributes.put(name, attribute(name));\n }\n return attributes;\n }", "public String getFieldName(int i) throws NoSuchElementException {\n if (i < 0 || i > numfields-1) {\n throw new NoSuchElementException();\n }\n if (attrNames == null || attrNames.length < (i+1)) {\n return null;\n }\n return attrNames[i];\n }", "public String[][] getNames () ;", "private List getList(Attribute attr){\n\t\tList retList;\n\t\tif(attr instanceof DiscreteAttribute){\n\t\t\tthis.labels = ChartF.getAxeLabels(attr);\n\t\t\tretList = getDisList((DiscreteAttribute)attr);\n\t\t} else {\n\t\t\tthis.labels = attr.getName();\n\t\t\tretList = getContList((ContinuousAttribute)attr);\n\t\t}\n\t\treturn retList;\n\t}", "List<String> getColumnIdentifiers();", "List<String> headerColumns();", "String getControllingAttributeName();", "String getAttribute();", "public String getColumnNameFour(){\n return columnNameFourLbl.getText();\n }", "@Override\n\tpublic String[] getFieldName() {\n\t\treturn new String[]{\"编码\",\"名称\",\"属性\"};\n\t}", "@Override\n\tpublic Enumeration<String> getAttributeNames(int arg0) {\n\t\treturn null;\n\t}", "Attributes getAttributes();", "public String getAttribute1() {\n return (String) getAttributeInternal(ATTRIBUTE1);\n }", "java.lang.String getColumn();", "@Override\n public int[] getAttributeIndexToRead()\n {\n java.util.ArrayList<Integer> attributes = new java.util.ArrayList<Integer>();\n //LN is static and read only once.\n if (LogicalName == null || LogicalName.compareTo(\"\") == 0)\n {\n attributes.add(1);\n }\n //ScalerUnit\n if (!isRead(3))\n {\n attributes.add(3);\n }\n //Value\n if (canRead(2))\n {\n attributes.add(2);\n } \n return toIntArray(attributes);\n }", "public List<AttributeColumn> getAllAttributeColumns() {\n\t\treturn Collections.unmodifiableList(attributeColumns);\n\t}", "Map<String, String> getAttributes();", "@Override\n\tpublic Enumeration<String> getAttributeNames() {\n\t\treturn null;\n\t}", "@Override\n\tpublic Enumeration<String> getAttributeNames() {\n\t\treturn null;\n\t}", "public String getAttribute1() {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "public String getAttribute1() {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "public String getAttribute1() {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "public String getAttribute1() {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "public String getAttribute1() {\n return (String)getAttributeInternal(ATTRIBUTE1);\n }", "@Override\r\n\tpublic String[] getPrettyColumnNames() {\n\t\treturn this.dispColNames;\r\n\t\t//未实现\r\n\t}", "public Set<String> getColumns();", "public List<Attribute> list() {\n String sql = \"select * from attributes \" +\n \"order by value\";\n List<Attribute> attributes =\n (List<Attribute>) this.getSession().createSQLQuery(sql)\n .addEntity(Attribute.class)\n .list();\n return attributes;\n }", "@Override\n public String getColumnName(int iCol) {\n return ARR_STR_HEADERS[iCol];\n }", "public String getColumnName();", "@Override\n\tpublic ArrayList<String> getName() {\n\t\tArrayList<String> l = new ArrayList<String>();\n\t\tl.addAll(leftTable.getName());\n\t\tl.addAll(rightTable.getName());\n\t\treturn l;\n\t}", "public Map<String, String> getAttributes();", "public List<Attribute> getAttribute() {\n\t if (attribute==null) {\n\t attribute = new ArrayList<>();\n\t }\n\n\t return attribute;\n\t}", "public Tuple<String> getColumnNames() {\n return resultTable.getColumnNames();\r\n }", "private String loadAttributeName() {\n return parseMapField().getKey();\n }", "public ArrayList<Attribute> getAttributeList(){\n\t\t\n\t\treturn(child.getAttributeList());\n\t}", "public ArrayList<Attribute> getAttributeList(){\n\t\t\n\t\treturn(child.getAttributeList());\n\t}", "List<T> getAttributeSchema(){\r\n\t\treturn explanatorySet;\r\n\t}", "public List<Column> getColumns();", "public String getListAttributesPref()\n {\n Serializer<Collection<RecognizedElement>> serializer = new Serializer<Collection<RecognizedElement>>();\n return serializer.serialize(tree.getChildren());\n }", "public List<Pair<String, String>> getAttributes() {\n\t\treturn attributes;\n\t}", "@Override\n public List<String[]> namesAndValues() {\n List<String[]> nAv = new ArrayList<>();\n String[] m = {\"Meno\", this.meno};\n String[] i = {\"Iso\", this.iso};\n String[] b = {\"Brummitt 1\", this.brumit1.getMeno(), \"F Brumit1\"};\n nAv.add(m);\n nAv.add(i);\n nAv.add(b);\n return nAv;\n }" ]
[ "0.7185972", "0.7147023", "0.7037781", "0.6886781", "0.68217474", "0.6792866", "0.6701698", "0.6630431", "0.6545637", "0.6456863", "0.64546084", "0.64421695", "0.6415137", "0.6402202", "0.6398895", "0.6396641", "0.63815224", "0.636557", "0.6359269", "0.63479877", "0.6338941", "0.62557566", "0.61985075", "0.61954206", "0.6170693", "0.61658174", "0.6154056", "0.6150376", "0.6139468", "0.6130088", "0.6109581", "0.60816044", "0.60672694", "0.6066211", "0.6060471", "0.60483366", "0.6043456", "0.6041684", "0.6032357", "0.6030869", "0.60002875", "0.5992282", "0.5980357", "0.5976189", "0.59739876", "0.5965667", "0.59642565", "0.59581697", "0.59418917", "0.59340847", "0.59335315", "0.5908703", "0.5899504", "0.5892908", "0.589161", "0.58889043", "0.5877572", "0.587371", "0.5873537", "0.5866538", "0.58582836", "0.58505714", "0.5846259", "0.58385193", "0.583702", "0.5823371", "0.5813491", "0.58124727", "0.5808879", "0.5808069", "0.5792777", "0.57678366", "0.5767132", "0.576211", "0.5760834", "0.5760191", "0.5748199", "0.5742093", "0.5742093", "0.57274026", "0.57274026", "0.57274026", "0.57274026", "0.57274026", "0.57232684", "0.572324", "0.5693272", "0.56832963", "0.56765944", "0.56722337", "0.5660921", "0.5655951", "0.565178", "0.5636945", "0.5629101", "0.5629101", "0.56252", "0.56225973", "0.5620423", "0.56118757", "0.5611624" ]
0.0
-1
get the value of the table, names are stored in 1st column values are stored in 2nd column
public Object getValueAt(int row, int col) { //if row is greater than the total attributes length return null if (row > prop_names.size() - 1) return null; //if column is 0 then return the name of the attribute //as names are stored at nth row column 0 if (col == 0) return prop_names.get(row); //return null if there is no value stored for editor for that row if (prop_map.size() <= row) return null; //get the value of the attribute from editor return prop_map.get(row); //return super.getValueAt(row,color); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "protected Object getTableValue()\n\t\t{\n\t\t\treturn Value ;\n\t\t}", "String getValue(String column, int row);", "public Table<Integer, Integer, String> getData();", "public void get_TableValues(){\r\n\tFFM=99;\r\n\tADFM=99;\r\n\tDF=0;\r\n\tFLOAD=0;\r\n\t\r\n}", "Object getDataValue(String column, int row);", "Object getColumnValue(int colIndex);", "List<List<Object>> getTableValues();", "@Override\n\t\tpublic int getValueColumn() {\n\t\t\treturn valueColumn;\n\t\t}", "private static String[] getColumnValue(ServiceFieldTableRestRep table, ServiceFieldRestRep field) {\n List<String> values = Lists.newArrayList();\n Pattern pattern = Pattern.compile(table.getName() + \"\\\\[(\\\\d+)\\\\].\" + field.getName());\n for (String name : params.data.keySet()) {\n Matcher match = pattern.matcher(name);\n if (match.matches()) {\n int index = Integer.valueOf(match.group(1));\n for (int i = values.size(); i <= index; i++) {\n values.add(null);\n }\n values.set(index, params.get(name));\n }\n }\n return values.toArray(new String[values.size()]);\n }", "java.lang.String getColumn();", "List<List<Object>> getTableValues(TableParameters tableParameters);", "private String[][] getTableData (JTable table,int[] dim) {\n\t DefaultTableModel model = (DefaultTableModel) table.getModel();\n\t int rowNo = model.getRowCount(), colNo = model.getColumnCount();\n\t dim[0] = rowNo;\n\t dim[1] = colNo;\n\t logInfo(\"rowNo:\"+rowNo+\" colNo:\"+colNo);\n\t String[][] tableData = new String[rowNo][colNo];\n\t for (int i = 0 ; i < rowNo ; i++) {\n\t for (int j = 0 ; j < colNo ; j++) {\n\t tableData[i][j] = model.getValueAt(i, j) != null ? model.getValueAt(i,j).toString() : \"\\\"\\\"\";\n\t logInfo(\"i:\"+i+\" j:\" + j + \" \" + tableData[i][j]);\n\t }\n\t }\n\t return tableData;\n\t}", "public void readValuesfromtableWithoutHeadings()\n\t {\n\t\t open();\n\t\t List<Map<Object, String>> tab1= withColumns(\"Last Name \" ,\"First Name\",\"Email\", \"Due\" , \"Web Site\" , \"My Test\") \n\t\t\t\t .readRowsFrom(table);\n\t\t System.out.println(tab1);\n\t }", "List<String> get_attribute_name(String table) {\n //table does not exist\n if (!get_table_names().contains(table) && !table.equals(\"relationship\")) {\n throw new RuntimeException(\"Table does not exist.\");\n }\n\n LinkedList<String> res = new LinkedList<>();\n\n String sql = \"select * from \" + table;\n\n ResultSet resultSet = execute_statement(sql, true); //get all data records\n try {\n ResultSetMetaData rsmd = resultSet.getMetaData();\n int column_cnt = rsmd.getColumnCount();\n for (int i=2; i <= column_cnt; i++) {\n res.add(rsmd.getColumnName(i)); //add column name\n }\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n try {\n this.disconnect(resultSet, null, null); //disconnect from database\n } catch (SQLException e) {\n e.printStackTrace();\n }\n\n return res;\n }", "String getColumnName();", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String value() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "public String getValue() {\n return this.column;\n }", "String getColumn();", "private String getStringValueFromSelectedTableTableByFieldCode(String tableName, String value, String fieldCode, String indexColumn) throws CantCheckAssetReceptionProgressException, UnexpectedResultReturnedFromDatabaseException {\n try {\n this.database=openDatabase();\n DatabaseTable databaseTable = getDatabaseTable(tableName);\n databaseTable.setStringFilter(indexColumn, value, DatabaseFilterType.EQUAL);\n databaseTable.loadToMemory();\n DatabaseTableRecord databaseTableRecord;\n List<DatabaseTableRecord> databaseTableRecords=databaseTable.getRecords();\n if (databaseTableRecords.size() > 1){\n this.database.closeDatabase();\n throw new UnexpectedResultReturnedFromDatabaseException(\"Unexpected result. More than value returned.\", indexColumn+\":\" + value);\n } else {\n databaseTableRecord = databaseTableRecords.get(0);\n }\n this.database.closeDatabase();\n String stringToReturn=databaseTableRecord.getStringValue(fieldCode);\n return stringToReturn;\n } catch (CantExecuteDatabaseOperationException exception) {\n this.database.closeDatabase();\n throw new CantCheckAssetReceptionProgressException(exception, \"Trying to get \"+fieldCode,\"Cannot find or open the database\");\n } catch (CantLoadTableToMemoryException exception) {\n this.database.closeDatabase();\n throw new CantCheckAssetReceptionProgressException(exception, \"Trying to get \"+fieldCode,\"Cannot load the database into memory\");\n }\n }", "public String getColumnNameOne(){\n return columnNameOneLbl.getText();\n }", "public int getValue()\n { \n return table.get(getSelectedItem());\n }", "Column getCol();", "public String getColumnNameTwo(){\n return columnNameTwoLbl.getText();\n }", "protected String getTableColumn()\n\t\t{\n\t\t\treturn Column ;\n\t\t}", "String getValueName();", "WebElement getColumnByName(WebElement tableRecord, String columnName);", "protected String getByColumn(boolean all, String table_name, String column_name, String name)\n\t{\n\t\tStatement statement = null;\n\t\tResultSet rs = null;\n\t\tString result = \"\";\n\t\tif(!table_name.equals(\"\"))\n\t\t{\n\t\t\t// initializing the query statement\n\t\t\ttry {statement = connection.createStatement();} \n\t\t\tcatch (SQLException e) {}\n\t\t\t\n\t\t\t\t\t\n\t\t\t// executing query to database\n\t\t\ttry {\n\t\t\t\t\n\t\t\t\tif(all) // Check if we need to get all the data on this column\n\t\t\t\t{\n\t\t\t\t\trs = statement.executeQuery(\"SELECT \" + column_name + \" FROM \" + table_name + \"\");\n\t\t\t\t\twhile(rs.next()) result = rs.getString(column_name);\n\n\t\t\t\t}\n\t\t\t\telse {\n\t\t\t\t\trs = statement.executeQuery(\"SELECT \" + column_name + \" FROM \" + table_name + \" WHERE name = \\\"\" + name + \"\\\"\");\n\t\t\t\t\twhile(rs.next()) result = rs.getString(column_name); // Putting the data in result variable to be return\n\t\t\t\t}\n\n\t\t\t} catch (SQLException e) {e.printStackTrace();}\n\t\t}\n\n\t\treturn result;\n\t}", "public String getColumnName();", "protected String getUserValues(String name){\n\t\tPreparedStatement getValuesStatement = null;\n\t\tString returnValueString = \"I dunno\";\n\t\ttry {\n\t\t\tString getValuesString = \"select * from responses where userName = ?\";\t\t\n\t\t\tgetValuesStatement = conn.prepareStatement(getValuesString);\t\t\t\n\t\t\tgetValuesStatement.setString(1, name);\t\t\t\n\t\t\tResultSet values = getValuesStatement.executeQuery();\n\t\t\tif(values.first()){\n\t\t\t\tint v1 = values.getInt(2);\n\t\t\t\tint v2 = values.getInt(3);\n\t\t\t\tint v3 = values.getInt(4);\n\t\t\t\tint v4 = values.getInt(5);\n\t\t\t\treturnValueString = \n\t\t\t\t\t\"<p> Op-perf: \" + v1 \n\t\t\t\t\t+ \"<p> Tech-perf: \" + v2 \n\t\t\t\t\t+ \"<p> Proj-sched: \" + v3 \n\t\t\t\t\t+ \"<p> Budget: \" + v4 ;\n\t\t\t}\n\t\t\treturn returnValueString;\n\t\t}catch (SQLException e){\n\t\t\treturn \"Error: While handsome, Greg seems to have missed something.\";\n\t\t}\n\t}", "public Object getValueAt(int row, int col) {\n\t\t\tif ( nodes == null ) return null;\n\t\t\tif ( nodes.size() == 0 ) return null;\n\t\t\tif ( row > (nodes.size()-1 ) ) return null;\n\t\t\tif ( row < 0 )\n\t\t\t\treturn getColumnType(col);\n\t\t\trcNode n = null;\n\t\t\ttry {\n\t\t\t n = vnodes.elementAt(row) ;\n\t\t\t} catch(Exception ex) {\n\t\t\t n = null;\n\t\t\t}\n\t\t\tif ( n == null ) return null;\n\t\t\t//return node if column is negative\n\t\t\tif ( col==-1 )\n\t\t\t\treturn n;\n\t\t\tif ( col <0 )\n\t\t\t\treturn null;\n\t\t\t\n\t\t\tObject obj;\n\t\t\tString codename = getColumnCodeName(col);\n\t\t\tif ( codename.equals(\"Reflector\") ) return n==null?null:n.UnitName;\n\t\t\telse if ( codename.equals(\"Hostname\") ) return n==null || n.client==null?\"???\":n.client.hostName;\n\t\t\telse if ( codename.equals(\"Load\") ) {\n\t\t\t\tobj = n.haux.get(\"Load\");\n\t\t\t\tif ( obj == null )\n\t\t\t\t\treturn \"???\";\n\t\t\t\treturn \"\"+((DoubleContainer)obj).getValue();\n\t\t\t} else if ( codename.equals(\"Video\") ) {\n\t\t\t\tobj = n.haux.get(\"Video\");\n\t\t\t\tif ( obj == null )\n\t\t\t\t\treturn \"0\";\n\t\t\t\treturn \"\"+((int)((DoubleContainer)obj).getValue());\n\t\t\t} else if ( codename.equals(\"Audio\") ) {\n\t\t\t\tobj = n.haux.get(\"Audio\");\n\t\t\t\tif ( obj == null )\n\t\t\t\t\treturn \"0\";\n\t\t\t\treturn \"\"+((int)((DoubleContainer)obj).getValue());\n\t\t\t} else if ( codename.equals(\"MLVer\") ) return n==null || n.client==null?\"???\":n.client.mlVersion;\n if ( /* col == 2 */codename.equals(\"JavaVer\"))\n return getJavaVersion(n);\n\t\t\telse if ( codename.equals(\"ReflVer\") ) { \n\t\t\t\tString ver = (String) n.haux.get(\"ReflVersion\");\n\t\t\t\treturn (ver == null || ver.length() == 0 ? \"N/A\" : ver);\n\t\t\t}else if ( codename.equals(\"MLUptime\") )\n\t\t\t\treturn n.client.uptime;\n\t\t\telse if ( codename.equals(\"Group\") ) \n\t\t\t\treturn (n!=null && n.client!=null && n.client.mle !=null) ? n.client.mle.Group:\"???\";\n\t\t\treturn null;\n\t\t}", "public Row getValue()\n\t{\n\t\treturn valueList;\n\t}", "@Override\r\n public Object getValueAt(int rowIndex, int columnIndex) {\n Hashtable rowData = fixHashtables[rowIndex];\r\n return rowData.get(getColumnName(columnIndex));\r\n }", "public String getTable()\n {\n return table;\n }", "public ArrayList<HashMap<String, String>> retrieve(String tableName, String colName, String value) {\n //GET Qualifiing Rows from DB\n select(tableName, colName, value, true);\n\n return this.processRetrieve();\n }", "private String[] getTableFields(String pTableName) {\r\n\t\tString[] returnedValue = null;\r\n\t\t\r\n\t\tif (getDatabse() != null && getDatabse().isOpen()) {\r\n\t\t\t\r\n\t\t\tCursor cursor = getDatabse().query(pTableName, null, null, null, null, null, null);\r\n\t\t\tif (cursor != null) {\r\n\t\t\t\treturnedValue = cursor.getColumnNames();\r\n\t\t\t}\r\n\t\t\tcursor.close();\r\n\t\t\tcursor = null;\r\n\t\t\t\r\n\t\t}\r\n\t\t\r\n\t\treturn returnedValue;\r\n\t}", "String getColumn(int index);", "String getColumn(int index);", "String getTabela();", "public String getid_prod(int row){\n DefaultTableModel dt =(DefaultTableModel)this.jTable1.getModel();\n String id_prod=\"\";\n id_prod = jTable1.getModel().getValueAt(row, 0).toString().trim();\n return id_prod;\n }", "public EntryRow getData(String TableName, String idKey, Object idValue) throws SQLException, NullPointerException {\n if(!valueExists(TableName, idKey, idValue.toString())) return null;\n\n ResultSet rs = mysql.query(\"SELECT * FROM `\" + TableName + \"` WHERE `\" + idKey + \"` LIKE '\" + idValue + \"'\");\n\n if(rs.next()) {\n Value[] values = new Value[rs.getMetaData().getColumnCount()];\n\n for(int columnIndex = 1; columnIndex <= rs.getMetaData().getColumnCount(); columnIndex++){\n int javaIndex = columnIndex-1;\n String key = rs.getMetaData().getColumnName(columnIndex);\n Object value = rs.getObject(columnIndex);\n\n values[javaIndex] = new Value(key, value);\n } // END OF FOR LOOP\n\n return new EntryRow(TableName, rs.getRow(), idKey, idValue, values);\n } // END OF rs.next IF\n\n return null;\n }", "public String get_another_field(String table, String source_field, String source_value, String destination_field);", "Table getTable();", "public int getValue(int row, int column);", "private Object getEntry( Object[] row, String rrName ) {\n Integer icol = colMap_.get( rrName );\n return icol == null ? null : row[ icol.intValue() ];\n }", "public ArrayList<HashMap<String, String>> retrieve(String tableName, String colName, long value) {\n //GET Qualifiing Rows from DB\n select(tableName, colName, String.valueOf(value), false);\n \n return this.processRetrieve();\n }", "public String getString(String columnLabel) throws SQLException;", "public Relatorio get(int row){\n\t\t\t\t\n\t\t\t\treturn valores.get(row);\n\t\t\t}", "public void selectFromTable(String tableName){\n //SQL query\n String query = \"SELECT * FROM \" + tableName;\n\n try {\n //connection\n stmt = con.createStatement();\n //execute query\n rs = stmt.executeQuery(query);\n System.out.println(\"\\nid\\t\\tmyName\\t\\taddress\\n____________________________________\");\n\n //get data\n while (rs.next()){\n int id = rs.getInt(1); //returns the id / first column\n String myName = rs.getString(\"myName\"); //returns my name\n String address = rs.getString(\"address\"); //returns my name\n System.out.println(id + \"\\t\\t\" + myName + \"\\t\\t\" + address);\n }\n }\n catch (SQLException ex){\n System.out.println(\"\\n--Query did not execute--\");\n ex.printStackTrace();\n }\n }", "public String getValueAt(int rowIndex, int columnIndex);", "List<Map<String, Object>> getTableValuesWithHeaders();", "@Override\n\tpublic V get(Object key) {\n\t\tfor (int i = 0; i < tabla.size(); i++) {\n\t\t\tint indice = tabla.get(i).keySet().indexOf(key);\n\t\t\tif (indice != -1) {\n\t\t\t\treturn tabla.get(i).valueSet().get(indice);\n\t\t\t}\n\t\t}\n\t\treturn null;\n\t}", "public abstract String[] getRowValues(Cursor c);", "public Object getValueAt(int row, int column) {\n Preso cli = lista.get(row);\n /*if (column == Id) {\n return cli.getId();\n } else*/ if (column == Nome) {\n return cli.getNome();\n } if (column == Tempo) {\n return cli.getTempo();\n } else\n\n return \"\"; //Nunca deve ocorrer \n }", "private String getAttributeValue() {\n\t\tString attributes = \"\";\r\n\t\tfor(int i=0;i< JTable1.getRowCount();i++ ) {\r\n\t\t\tString attributename = ((String) JTable1.getValueAt(i, 0)).trim();\r\n\t\t\tString attributeValue = ((String) JTable1.getValueAt(i, 1)).trim();\r\n\t\t\t//attributeValue.trim();\r\n\t\t\tif(attributeValue != null && attributeValue.length() > 0)\r\n\t\t\tattributes = attributes.trim() + attributename+ \"=\" + attributeValue + \";\";\r\n\t\t\t\r\n\t\t}\r\n\t\tif(attributes.trim().length() > 0)\r\n\t\treturn attributes.substring(0, attributes.length()-1);\r\n\t\treturn attributes;\r\n\t}", "public String getColumnone() {\n return columnone;\n }", "public static String[][] getTableData(){\n int row=getRowCount();//jgets total number of non empty rows\n String TableData[][]=new String[row][6]; \n for(int i=0; i<row;i++){\n for(int j=0; j<6; j++){\n TableData[i][j]=(String)jTable1.getValueAt(i, j);\n }\n }\n return TableData; //returns table data\n }", "@Override\r\n public Object getValueAt(int rowIndex, int columnIndex) {\n Hashtable rowData = chineseHashtables[rowIndex];\r\n return rowData.get(getColumnName(columnIndex));\r\n }", "public String getCol2value() {\n return col2value;\n }", "public String fetchData(String tableName, int id, String columnName) throws SQLException {\n\n\t\ttry {\n\t\t\tSystem.out.println(\"Id of the Products is \" + id);\n\n\t\t\tSystem.out.println(\"select \" + columnName + \" from \" + tableName + \" where \"\n\t\t\t\t\t+ getPrimaryKeyColumnName(tableName) + \" = \" + id);\n\n\t\t\trs = stmt.executeQuery(\"select \" + columnName + \" from \" + tableName + \" where \"\n\t\t\t\t\t+ getPrimaryKeyColumnName(tableName) + \" = \" + id);\n\n\t\t\twhile (rs.next()) {\n\t\t\t\tSystem.out.println(rs.getString(1));\n\t\t\t\treturn rs.getString(1);\n\t\t\t}\n\t\t} catch (Exception e) {\n\t\t\tSystem.out.println(\"Sorry! wrong Input\");\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn rs.getString(1);\n\t}", "public Object[] getColumn(int c) {\n// Object[] dta = new Object[data.rows];\n// for (int i = 0; i < data.rows; i++)\n// dta[i] = data.values[c][c];\n return data.values[c];\n }", "IExtensionPoint getTableValue(String rowId, String columnId) {\n lock.readLock().lock();\n try {\n return extensionPointPluginMap.contains(rowId, columnId)\n ? extensionPointPluginMap.get(rowId, columnId).get()\n : null;\n } finally {\n lock.readLock().unlock();\n }\n }", "public String getEmphcolumn()\n {\n return emphColumn;\n }", "protected Object getCellValue(int row, String column) {\r\n\r\n\t\t// translate\r\n\t\tif(NAME.equals(column))\r\n\t\t{\r\n\t\t\tIUnitIf unit = getId(row);\r\n\t\t\tString name = MsoUtils.getUnitName(getId(row), true);\t\t\t\r\n\t\t\treturn unit.isChanged()?name.concat(\"*\"):name;\r\n\t\t}\r\n\t\telse if(VIEW.equals(column))\r\n\t\t\treturn getId(row);\r\n\r\n\t\t// not supported\r\n\t\treturn null;\r\n\r\n\t}", "public String getNomTable();", "Object getDataValue(final int row, final int column);", "private HashMap<Long, String> getTable() {\n return table;\n }", "public Object getValueAt(int row, int col) {\n\t\treturn (col == 0) ? prescaleTable.pathName(row) : prescaleTable.prescale(row, col - 1);\n\t}", "public String[] getColumnNames(T1 ob) {\n\t\tjava.lang.reflect.Field[] f1=ob.getClass().getDeclaredFields(); \r\n\t\tString[] s =new String[f1.length-1];\t\r\n\t\t//JOptionPane.showMessageDialog(null,f1.length); \r\n\t\tfor(int i=0;i<f1.length-1;i++)\r\n\t\t{\r\n\t\t\t String name = f1[i].getName(); //获取属性的名字\r\n\t\t\t String type = f1[i].getGenericType().toString(); //获取属性的类型\r\n\t if(type.equals(\"class java.lang.String\")){ //如果type是类类型,则前面包含\"class \",后面跟类名\r\n\t\t name=name.substring(0, 1).toUpperCase()+name.substring(1);\r\n\t\t //JOptionPane.showMessageDialog(null,name);\r\n\t\t Method m = null;\r\n\t\t\ttry {\r\n\t\t\t\tm = ob.getClass().getMethod(\"get\"+name);\r\n\t\t\t} catch (SecurityException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (NoSuchMethodException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t}\r\n\t String value = null;\r\n\t\t\ttry {\r\n\t\t\t\tvalue = (String) m.invoke(ob);\r\n\t\t\t} catch (IllegalArgumentException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (IllegalAccessException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} catch (InvocationTargetException e1) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te1.printStackTrace();\r\n\t\t\t} //调用getter方法获取属性值\r\n\t if(value != null){\t \r\n\t s[i]=value;\r\n\t\t\t\t //JOptionPane.showMessageDialog(null,value);\r\n\t }\r\n\t\t\t\t\r\n\t\t\t}\t\r\n\t\t }\r\n\t\t//JOptionPane.showMessageDialog(null,s.size());\r\n\t return s;\r\n\t\t\r\n }", "public String getTableData() {\r\n return tableData;\r\n }", "public Table getTable() { \n\t\treturn this.table; \n\t}", "public Object getValueAt(int row, int column){\n return dataEntries[row][column];\n }", "public String getTable() {\n return table;\n }", "public Object getValueAt(int row, int column) {\r\n if (_debugTable == null) {\r\n return \"\" ;\r\n }\r\n try {\r\n Object o = _debugTable.getTableCell(row, column) ;\r\n return (o != null) ? o : \"\" ;\r\n } catch (Exception e) {\r\n return \"\" ;\r\n }\r\n }", "public String getTable() {\n return table;\n }", "public abstract Object getValueAt(int nodeIndex,int nodeRow,int nodeColumn);", "public String getData(int id){\n String _data = \"\";\n dbOperation operationObj = new dbOperation(getActivity());\n operationObj.open();\n MyTable fields = new MyTable();\n String condition2 = fields.getID() + \" ='\" + id + \"'\";\n String[] dbFields4 = {fields.getScore()};\n Cursor cursor2 = operationObj.getTableRow(fields.getTableName(),dbFields4,condition2,fields.getID() + \" ASC \",\"1\");\n if(cursor2.getCount() > 0)\n {\n cursor2.moveToFirst();\n do{\n _data = cursor2.getString(0);\n }while(cursor2.moveToNext());\n }else{\n _data = \"error\";\n }\n cursor2.close();\n cursor2.deactivate();\n operationObj.close();\n return _data;\n }", "@Override\n public Object getValueAt(int row, int column) { return data[row][column]; }" ]
[ "0.7125729", "0.69375664", "0.6634007", "0.64568114", "0.6438691", "0.6352218", "0.6336585", "0.6335755", "0.6174293", "0.6162174", "0.6152261", "0.6119018", "0.6112524", "0.6093699", "0.6083084", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.60381955", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.6033118", "0.60252637", "0.6014253", "0.60110205", "0.5986259", "0.5964746", "0.5948431", "0.59356505", "0.58877504", "0.5887415", "0.585333", "0.5832693", "0.5830801", "0.5802124", "0.57918775", "0.57895046", "0.5767575", "0.5749301", "0.57394195", "0.5736603", "0.5736603", "0.5724941", "0.57183886", "0.57086176", "0.5705424", "0.57005006", "0.5695007", "0.5692132", "0.5690247", "0.566159", "0.56583095", "0.56517524", "0.5649013", "0.5643014", "0.5622528", "0.5619792", "0.5600217", "0.5597589", "0.5590612", "0.55871814", "0.5583027", "0.5582075", "0.5579253", "0.5575574", "0.55709916", "0.55708027", "0.55692095", "0.5569197", "0.55659235", "0.55449045", "0.5538139", "0.5532733", "0.5524728", "0.55244386", "0.55169094", "0.5516848", "0.5515911", "0.5507029", "0.5493561", "0.5484905", "0.5480417" ]
0.0
-1
change the value at the given row and column
public void setValueAt(Object value, int row, int col) { if (col != 1) return; prop_map.put(row,value); fireTableCellUpdated(row, col); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void set(int row, int col, double value){\n \tarray[row-1][col-1] = value;\n }", "public void setValueAt(Object value, int row, int col)\r\n throws IllegalStateException {\r\n\r\n if(columnsAreNum != null && columnsAreNum.length>0){\r\n\t for(int i =0; i< columnsAreNum.length; i++){\r\n\t if(col == columnsAreNum[i]){\r\n\t value = new Double(tranferStringToNum(value.toString()));\r\n\t break;\r\n\t }\r\n\t }\r\n\t}\r\n //Set value at cell\r\n ( (Vector) data.elementAt(row)).setElementAt(value, col);\r\n //Set status modify to this row.\r\n if (!(Integer.parseInt( ( (Vector) data.elementAt(row)).elementAt\r\n (numberOfcolumns).toString()) == IS_INSERTED)) {\r\n ((Vector) data.elementAt(row)).setElementAt(new Integer(IS_MODIFIED),\r\n numberOfcolumns);\r\n this.updatedStatus = true;\r\n }\r\n }", "public void set( int row, int column, double value )\n\t{\n\t\tmatrixData[ row - 1 ][ column - 1 ]\t= value;\n\t}", "public abstract void setCellValue(int cellValue, int row, int col);", "@Override\n public void setValueAt(Object value, int row, int column) { data[row][column] = value; }", "public void setValue(int row, int col, int value) {\n this.matrix[row][col] = value;\n }", "public void setValueAt(Object value, int row, int column){\n dataEntries[row][column] = value;\n }", "protected abstract double setCell(\r\n int row,\r\n int col,\r\n double valueToSet);", "@Override\n public void setValueAt(Object value, int row, int column) {\n this.data[row][column] = value;\n fireTableDataChanged();\n }", "public void set( int row, int col, double value ) {\n ops.set(mat, row, col, value);\n }", "@Override\n public void setValueAt(Object aValue, int aRow, int aColumn) {\n model.setValueAt(aValue, aRow, aColumn); \n }", "public void setValue(int column, int row, int newValue) {\n\t\tint goodValue = newValue;\n\t\tif (goodValue < 0) {\n\t\t\tgoodValue = 0;\n\t\t}\n\t\tif (this.hasMaximumValue) {\n\t\t\tif (goodValue > this.maximumValue) {\n\t\t\t\tgoodValue = this.maximumValue;\n\t\t\t}\n\t\t}\n\n\t\tthis.bitmap[column][row] = goodValue;\n\t}", "public void setValueAt(Object aValue, int row, int col)\n\t{\n\t\t// invalid row\n\t\tif (row < 0 || row >= m_data.rows.size())\n\t\t\tthrow new IllegalArgumentException(\"Row invalid\");\n\t\tif (col < 0 || col >= m_data.cols.size())\n\t\t\tthrow new IllegalArgumentException(\"Column invalid\");\n\t\tif (!isCellEditable(row, col)){\n\t\t\tthrow new IllegalArgumentException(\"Cell is read only\");\n\t\t\t\n\t\t}\n\t\t\t//\n\t\tArrayList<Object> myRow = m_data.rows.get(row);\n\t\t// invalid row\n\t\tif (myRow == null)\n\t\t\tthrow new java.lang.IllegalArgumentException(\"Row not initialized\");\n\t\t// not enough columns - add nulls\n\t\tif (col >= myRow.size())\n\t\t\twhile (myRow.size() < m_data.cols.size())\n\t\t\t\tmyRow.add(null);\n\t\t// setValue\n\t\tmyRow.set(col, aValue);\n\t}", "public void setCell(Object value, int col, int row) {\n ((DefaultTableModel) getModel()).setValueAt(value, row, col);\n }", "private Object set( int r, int c, Object newVal ) {\n\tObject oldVal = matrix[r][c];\n\tmatrix[r][c] = newVal;\n\treturn oldVal;\n }", "public void setValueAt(Object value, int row, int col) {\n if(row < getRowCount()){\n if (DEBUG) {\n System.out.println(\"Setting value at \" + row + \",\" + col\n + \" to \" + value\n + \" (an instance of \"\n + value.getClass() + \")\");\n }\n String[] r = data.get(row);\n r[col] = (String) value;\n fireTableCellUpdated(row, col);\n\n if (DEBUG) {\n System.out.println(\"New value of data:\");\n printDebugData();\n }\n }\n }", "public void setValueAt(Object val, int row, int col) {\r\n }", "private void setTile(int row, int col, int value) {\n //first make sure the parameters are reasonable values\n if (row < 0 || row > 2 || col < 0 || col > 2) {\n throw new IllegalArgumentException(\"Passed bad index values to setTile()\");\n }\n tiles[row][col] = value;\n }", "public void setValueAt(Object aValue, int row, int column)\n {\n\n }", "@Override\n public void setQuick(int row, int column, double value) {\n base.setQuick(rowPivot[row], columnPivot[column], value);\n }", "public void setValueAt(Object value, int row, int column)\n\t{\n\t\tgetModel().setDataAt(value, row, convertColumnIndexToModel(column));\n\t}", "public void setValue(int row, int col, double value) {\n data[row][col] = value;\n }", "public void setCell(int row, int col, double value) {\n int di = row - col;\n\n if (di == 0) {\n B[row] = value;\n } else if (di == -1) {\n C[row] = value;\n } else if (di == 1) {\n A[row] = value;\n } else {\n throw new IllegalArgumentException(\"Only the main, super, and sub diagonals can be set.\");\n }\n }", "public void setValueAt(Object value, int row, int col) {\n\t\t// data[row][col] = value;\n\t\tfireTableCellUpdated(row, col);\n\t}", "public void setValue(int row, int col, double value) throws IndexOutOfBoundsException {\r\n matrix[row][col] = value;\r\n }", "public final void setElement(int row, int column, float value) {\n\t\t\n \tif(row == 0) {\n \t\t\n\t\t if(column == 0) {\n\t\t\t\n\t\t \tm00 = value;\n\t\t \t\n\t\t } else if(column == 1) {\n\t\t\t\n\t\t \tm01 = value;\n\t\t \t\n\t\t } else if(column == 2) {\n\t\t\t\n\t\t \tm02 = value;\n\t\t \t\n\t\t } else {\n\t\t\t\n\t\t \tthrow new ArrayIndexOutOfBoundsException(\"column must be 0 to 2 and is \" + column);\n\t\t }\n\t\t \n\t\t} else if(row == 1) {\n\t\t\t\n\t\t if(column == 0) {\n\t\t\t\n\t\t \tm10 = value;\n\t\t \t\n\t\t } else if(column == 1) {\n\t\t\t\n\t\t \tm11 = value;\n\t\t \t\n\t\t } else if(column == 2) {\n\t\t \t\n\t\t \tm12 = value;\n\t\t \n\t\t } else {\n\t\t\t\n\t\t \tthrow new ArrayIndexOutOfBoundsException(\"column must be 0 to 2 and is \" + column);\n\t\t }\n\t\t \n\t\t} else if(row == 2) {\n\t\t\t\n\t\t if(column == 0) {\n\t\t\t\n\t\t \tthis.m20 = value;\n\t\t \t\n\t\t } else if(column == 1) {\n\t\t\t\n\t\t \tthis.m21 = value;\n\t\t \t\n\t\t } else if(column == 2) {\n\t\t\t\n\t\t \tthis.m22 = value;\n\t\t \t\n\t\t }else {\n\t\t\t\n\t\t \tthrow new ArrayIndexOutOfBoundsException(\"column must be 0 to 2 and is \" + column);\n\t\t }\n\t\t \n\t\t} else {\n\t\t\t\n\t\t\tthrow new ArrayIndexOutOfBoundsException(\"row must be 0 to 2 and is \" + row);\n\t\t}\n }", "@Override\n public void setValueAt( Object aValue, Object node, int column )\n {\n }", "@Override\n\tpublic void setValueAt(Object value, int row, int column) {\n\t\tswitch (column) {\n\t\tcase 0:\n\t\t\tString expr = value.toString();\n\t\t\texpressions.set(row, expr);\n\t\t\tString result = executeExpr(expr, row);\n\n\t\t\tvalues.set(row, result);\n\t\t\tupdateModel();\n\t\t\tif (row + 1 == expressions.size()) {\n\t\t\t\texpressions.add(\"\");\n\t\t\t\tvalues.add(\"\");\n\t\t\t\tfireTableRowsInserted(row + 1, row + 1);\n\t\t\t}\n\t\t\tbreak;\n\t\tcase 1:\n\t\t\t// just reset column 2; ignore edits\n\t\t\tfireTableDataChanged();\n\t\t}\n\t}", "public void setValueAt(Object value,int row, int col)\n {\n\tif (col==1) {\n\t smartPrescaleTable.modRowSetScale(row, (Long)value);\n\t //fireTableStructureChanged();\n\t fireTableDataChanged();\n\t return;\n\t}\n\t\n\tString strCondition = SmartPrescaleTable.regularise((String)value);\n\tif(strCondition.equals(\"\")) return;\n\n\tStringTokenizer pathTokens = new StringTokenizer(strCondition,\"/ \");\n\n\twhile ( pathTokens.hasMoreTokens()) {\n\t String strPath = pathTokens.nextToken().trim();\n\t if (strPath.length()<5) continue;\n\t int g = -10000;\n\t try { \n\t\tg = Integer.parseInt(strPath); \n\t }catch (NumberFormatException e) { \n\t\tg = -10000;\n\t }\n\t if ( (g<0)\n\t\t && ! strPath.equals(\"FALSE\")\n && ! (strPath.indexOf(\"*\") >= 0) // quick hack to allow wildcards\n\t\t && ! smartPrescaleTable.checkL1TCondExists(strPath)\n\t\t && ! smartPrescaleTable.checkHLTPathExists(strPath) ) {\n\t\treturn;\n\t }\n\t}\n\n\t// replace conditions containing only FALSE by empty conditions\n\tstrCondition = SmartPrescaleTable.simplify(strCondition);\n\n\tif (!strCondition.equals(\"\")) {\n\t smartPrescaleTable.modRow(row,strCondition);\n\t //fireTableStructureChanged();\n\t fireTableDataChanged();\n\t}\n }", "public void setValueAt(Object value, int row, int col) {\r\n this.variableData.get(row).remove(col);\r\n this.variableData.get(row).add(col, value);\r\n fireTableCellUpdated(row, col);\r\n }", "private void setCell(int x, int y, int newValue) {\n hiddenGrid[x][y] = newValue;\n }", "public void setValueAt(Object value, int row, int col) {\r\n pvValues[row][col] = value;\r\n fireTableCellUpdated(row, col);\r\n }", "@Override\n public void setValueAt(Object value, int row, int col) {\n data[row][col] = value;\n fireTableCellUpdated(row, col);\n }", "public void set( int row, int column, T obj ) throws ArrayIndexOutOfBoundsException {\n\n\t\tString S = C + \": set(): \";\n\t\tcheckBounds( row, column, S );\n\t\tdata[row * numCols + column] = obj;\n\n\t}", "public abstract void setCell(int row, int column, T item);", "public void setValueAt(Object value, int row, int col)\n\t{\n\t\tdatas.set(row,value);\n\t\tfireTableCellUpdated(row, col);\n\t}", "public void setValueAt(Object value, int row, int col) {\n\t\tList rowList = data.get(row);\n\t\t\n\t\t// make this row long enough\n\t\tif (col>=rowList.size()) {\n\t\t\twhile (col>=rowList.size()) rowList.add(null);\n\t\t}\n\n\t\t// install the data\n\t\trowList.set(col, value);\n\t\t\n\t\t// notify model listeners of cell change\n\t\tfireTableCellUpdated(row, col);\n\t}", "public void set(int row, int col)\n\t{\n\t\tthis.row = row;\n\t\tthis.col = col;\n\t}", "public void setRowAndColumn(int row, int column) {\n this.row = row;\n this.column = column;\n updateRowColumnDisplay();\n }", "void changeCellAt(int col, int row, String sexp);", "public void setValueAt(Object value, int row, int col) {\n\t\tprescaleTable.setPrescale(row, col - 1, (Integer) value);\n\n\t\tfireTableDataChanged(); // Fire event to alert a listener at ConfDbGUI.java (bug 89524).\n\t}", "public void setValueAt(Object obj, int row, int column) {\n Object[] rowValues = this.records.get(row);\n rowValues[column] = obj;\n fireTableDataChanged();\n }", "private static void replaceElement(int[][] matrix, int row, int column, int newElement) {\n\t\t\n\t\tmatrix[row][column] = newElement;\n\t}", "public void setValueAt(Object value, int row, int col) {\n\t\t\tsuper.setValueAt(value,row,col);\n\t\t\tif (DEBUG) {\n\t\t\t\tSystem.out.println(\"Changed a row at \" + row + \",\" + col\n\t\t\t\t\t\t\t\t + \" to \" + value\n\t\t\t\t\t\t\t\t + \" (an instance of \"\n\t\t\t\t\t\t\t\t + value.getClass() + \")\");\n\t\t\t}\n\n\t\t\tif (col==1 || col==2 || col==9){// length or Girth\n\t\t\t\tint bFt=0, bIn=0, breadthIn=0; double rateclass=0 ; double cft=0, amt =0.0; String wclass=\"\";\n\n\t\t\t\tStringTokenizer st = new StringTokenizer((getValueAt(row,2)).toString(),\".\");\n\t\t\t\t\t\t\t\tif (st.hasMoreTokens()) bFt= (new Integer(st.nextToken())).intValue();\n\t\t\t\t\t\t\t\tif (st.hasMoreTokens()) bIn= (new Integer(st.nextToken().trim())).intValue();\n\t\t\t\t\t\t\t\telse bIn = (new Integer(0)).intValue();\n\t\t\t\tbreadthIn = bFt *12 + bIn;\n\n\t\t\t\tdouble x = ((Double)getValueAt(row,1)).doubleValue();\n\t\t\t\tcft = (( x * breadthIn * breadthIn)/2304.0) * ((Integer)getValueAt(row,9)).intValue();\n\n\t\t\t\tConvertLobs.subTCFT((new Double((String)getValueAt(row,11))).doubleValue());\n\t\t\t\tConvertLobs.subAmount(((Double)getValueAt(row,10)).doubleValue());\n\n\t\t\t\tString cl = (String)getValueAt(row, 7);\n\t\t\t\t\t\t\tif (cl.equals(\"A\")) super.setValueAt(\" \", row, 3);\n\t\t\t\t\t\t\tif (cl.equals(\"B\")) super.setValueAt(\" \", row, 4);\n\t\t\t\t\t\t\tif (cl.equals(\"C\")) super.setValueAt(\" \", row, 5);\n\t\t\t\t\t\t\tif (cl.equals(\"D\")) super.setValueAt(\" \", row, 6);\n\n\t\t\t\tif ((breadthIn)>=Converter.classAlimit) { wclass = \"A\"; rateclass = Converter.rateA;\n\t\t\t\t\t\t\t\tamt = rateclass*cft;\n\t\t\t\t\t\t\t\tConvertLobs.subTCFTA((new Double((String)getValueAt(row,3))).doubleValue()); ConvertLobs.addTCFTA(cft);\n\t\t\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 11);\n\t\t\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 3);\n\t\t\t\t\t\t\t\t }\n\t\t\t\telse if ((breadthIn)>=Converter.classBlimit) {wclass = \"B\"; rateclass = Converter.rateB;ConvertLobs.addTCFTB(cft);\n\t\t\t\t\t\t\t\tamt = rateclass*cft;\n\t\t\t\t\t\t\t\tConvertLobs.subTCFTB((new Double((String)getValueAt(row,4))).doubleValue());\n\t\t\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 11);\n\t\t\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 4);\n\t\t\t\t\t\t\t\t}\n\t\t\t\telse if ((breadthIn)>=Converter.classClimit) {wclass = \"C\";rateclass = Converter.rateC; ConvertLobs.addTCFTC(cft);\n\t\t\t\t\t\t\t\t\t amt = rateclass*cft;\n\t\t\t\t\t\t\t ConvertLobs.subTCFTC((new Double((String)getValueAt(row,5))).doubleValue());\n\t\t\t\t\t\t\t super.setValueAt(new Double(cft).toString(), row, 11);\n\t\t\t\t\t\t\t super.setValueAt(new Double(cft).toString(), row, 5);\n\t\t\t\t\t\t\t\t\t }\n\t\t\t\telse if ((breadthIn)>=Converter.classDlimit) {wclass = \"D\";rateclass = Converter.rateD; ConvertLobs.addTCFTD(cft);\n\t\t\t\t\t\t\t\t\t\t\tamt = rateclass*cft;\n\t\t\t\t\t\tConvertLobs.subTCFTD((new Double((String)getValueAt(row,6))).doubleValue());\n\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 11);\n\t\t\t\t\t\tsuper.setValueAt(new Double(cft).toString(), row, 6);\n\t\t\t\t\t\t\t\t\t\t\t}\n\t\t\t\tsuper.setValueAt(wclass, row, 7);\n\t\t\t\tsuper.setValueAt(new Double(rateclass), row, 8);\n\t\t\t\tConvertLobs.addAmount(amt);\n\t\t\t\tsuper.setValueAt(new Double(amt), row, 10);\n\t\t\t\tConvertLobs.addTCFT(cft);\n\n\t\t\t}\n\n\t\t\tif (col == 12){// get row vector and get tcft\n\t\t\tDouble temp= new Double((String)getValueAt(row, col-1));\n\t\t\tConvertLobs.subTCFT(temp.doubleValue());\n\t\t\tDouble temp1= new Double((String)getValueAt(row, col-2));\n\t\t\tConvertLobs.subAmount(temp1.doubleValue());\n\t\t\tInteger temp2= (Integer)getValueAt(row, col-3);\n\t\t\tConvertLobs.subQuantity(temp2.intValue());\n\t\t\tConvertLobs.sno--;\n\t\t\tfor (int i=row-1; i >= 0; i--) super.setValueAt(new Integer( ((Integer)getValueAt(i,0)).intValue() - 1 ), i, 0);\n\n\t\t\tString cl = (String)getValueAt(row, col-5);//\n\t\t\tif (cl.equals(\"A\")) ConvertLobs.subTCFTA(temp.doubleValue());\n\t\t\tif (cl.equals(\"B\")) ConvertLobs.subTCFTB(temp.doubleValue());\n\t\t\tif (cl.equals(\"C\")) ConvertLobs.subTCFTC(temp.doubleValue());\n\t\t\tif (cl.equals(\"D\")) ConvertLobs.subTCFTD(temp.doubleValue());\n\n\t\t\t\t\t\t\tremoveRow(row);\n\t\t\t}\n\t\t\tif (col == 0){\n\t\t\t\tConvertLobs.sno = ((Integer)getValueAt(row,col)).intValue();\n\t\t\t}\n\n\t\t}", "public void update(int row, int col, int val) {\n int n = matrix[0].length;\n \n for(int i = col; i < n; i++){\n rowSums[row][i] = rowSums[row][i] - matrix[row][col] + val;\n }\n\n matrix[row][col] = val;\n }", "@Override\r\n\tpublic void setCell(Integer x, Integer y, Integer value) {\n\t\tgame[x][y] = value;\r\n\t}", "public void setValueAt(Object value, int row, int col) {\n \n \t\tFermentable m = (Fermentable) data.get(row);\n \t\ttry {\n \t\t\tswitch (col) {\n \t\t\t\tcase 0 :\n \t\t\t\t\tm.setName(value.toString());\n\t\t\t\t\tif (NewSwingApp.DEBUG){\n \t\t\t\t\t\tSystem.out.println(\"value is:\" + value);\n\t\t\t\t\t}\n \t\t\t\tcase 1 :\n \t\t\t\t\tm.setAmount(Double.parseDouble(value.toString()));\n \t\t\t\tcase 2 :\n \t\t\t\t\tm.setUnits(value.toString());\n \t\t\t\tcase 3 :\n \t\t\t\t\tm.setPppg(Double.parseDouble(value.toString()));\n \t\t\t\tcase 4 :\n \t\t\t\t\tm.setLov(Double.parseDouble(value.toString()));\n \t\t\t\tcase 5 :\n \t\t\t\t\tm.setCost(Double.parseDouble(value.toString()));\n \t\t\t\tcase 6 :\n \t\t\t\t\tm.setPercent(Double.parseDouble(value.toString()));\n \n \t\t\t}\n \t\t} catch (Exception e) {\n \t\t};\n \n \t\tfireTableCellUpdated(row, col);\n \t\t\n \t}", "public void setValueCurrentRow(final int column, final double value) {\r\n setValue(currentRow, column, value);\r\n }", "public void setVal(int row, int col, int val) {\n\t\tif(row < 0 || row >= dimension || col < 0 || col >= dimension || val < 0 || val > dimension)\n\t\t\tthrow new IllegalArgumentException(\"Parameters out of bounds\");\n\t\tpuzzle[row][col] = val;\n\t}", "public void updateRoomValue(String columnName, int roomId, Object value, int row, int column) {\r\n try {\r\n if (column != 0) {\r\n stmt.executeUpdate(\"UPDATE ROOMS SET \" + columnName\r\n + \" = '\" + value + \"' WHERE ID = \" + roomId);\r\n }\r\n } catch (SQLException err) {\r\n System.out.println(err.getMessage());\r\n }\r\n }", "public void setValueAt(Object value, int row, int col) {\r\n \tswitch(col){\r\n case 0:\r\n \tattributs.get(row).setPk((Boolean)value);\r\n \tbreak;\r\n case 1:\r\n \tSystem.out.println(value);\r\n \tattributs.get(row).setName((String)value);\r\n \tbreak;\r\n case 2:\r\n \tattributs.get(row).setType((String)value);\r\n \tbreak;\r\n case 3:\r\n \tattributs.get(row).setTaille((String)value);\r\n \tbreak;\r\n case 4:\r\n \tattributs.get(row).setNul((Boolean)value);\r\n \tbreak;\r\n case 5:\r\n \tattributs.get(row).setUk((Boolean)value);\r\n \tbreak;\r\n \t\r\n \t}\r\n fireTableCellUpdated(row, col);\r\n }", "void setElement(int row, String field, Object value);", "protected void set(int row, int col, Cell cell) {\n\t\tmyGrid.set(row, col, cell);\n\t}", "void setNumber (int col, int row, int number) {\n\t\tboardArray[col][row] = number;\n\t}", "public void setValueAt(Object value,int row, int col)\n {\n \tif (col==0) return;\n \tProductLogger product = products.get(row);\n \t\n \tif (col==1) product.info = (Boolean)value;\n \telse if (col==2) product.debug = (Boolean)value;\n \telse if (col==3) product.warning = (Boolean)value;\n }", "public void setRow(int value) {\n this.row = value;\n }", "public void set(int rowIndex, int columnIndex, int value) { target.set(index.get(rowIndex), columnIndex, value); }", "public void setPosition(int row, int column){\t\t\n\t\tposition[0] = row;\n\t\tposition[1] = column;\t\t\n\t}", "public void setPlayer(int row, int col, int value) {\n\t\tplayer[row][col] = value;\n\t}", "public void setBoard(int row, int col, int value) {\n this.board[row][col] = value;\n }", "void setNumber(int row, int col, int num){\n board[row][col].setNumber(num);\n }", "public void setRowCol(int row1, int col1){\n row = row1;\n col = col1;\n }", "public int getValue(int row, int column);", "public void setValueAt(Object value, int row, int col) {\n if (rows != null && row >=0 && row < rows.size()) {\n ExtendedAttributeRow singleRow = (ExtendedAttributeRow) rows.get(row);\n if (singleRow != null) {\n switch (col) {\n case iColName:\n singleRow.setName((String) value); \n break;\n case iColDefaultValue:\n singleRow.setDefaultValue((String) value); \n break;\n case iColSearchable:\n singleRow.setSearchable((String) value);\n break;\n case iColRequired:\n singleRow.setRequired((String) value);\n break;\n default:\n return;\n }\n }\n fireTableCellUpdated(row, col);\n }\n }", "public void set(int row, int col, double data) {\n if (row >= 0 && row < this.rows && col >= 0 && col < this.cols)\n this.data[row][col] = data;\n else\n throw new ArrayIndexOutOfBoundsException();\n }", "public void setCell(int row, int col, String val) {\n board[row][col] = val;\n }", "public boolean setCell(int row, int col, char value) {\n if (this.cells[row][col] instanceof Cell == false) return false;\n this.cells[row][col].setValue(value);\n return true;\n }", "public void setGrid(int x ,int y,char newValue){\n\t\tGrid[x][y] = newValue;\n\t}", "public void setValueOf( final Object value, final R row, final C columnEnum ) {}", "public void setRow(int row) {\n setRowAndColumn(row, column);\n }", "public void setElement(final int columnIndex, final int rowIndex,\n final int value) throws MatrixException {\n if (checkRange(columnIndex, rowIndex)) {\n values[columnIndex][rowIndex] = value;\n } else {\n throw new MatrixException(\"Выход за пределы массива.\");\n }\n }", "public void setInt(int data, int row, int column) {\n\t\tcolumns[column].setInt(data, subset[row]);\n\t}", "public void setCell(int dim, int row, int col ) {\n\n\t\tCell value = getEnumCell();\n\n\t\tif(isEmpty( dim, row, col)){\n\n\t\t\tboard[dim][row][col]= value;\n\n\t\t\tturn++;\n\t\t}\n\n\t\t//\t\telse System.out.println(value.toString() + \" cannot play there. Choose another location for\" + value.toString() + \" .\");\n\n\n\t}", "private void updateCell(LifeMatrix oldMatrix, LifeMatrix newMatrix, int row, int column) throws Exception {\n\t\tboolean oldVal = oldMatrix.getCellValue(row, column);\n\t\tint numNeighbors = oldMatrix.numberOfNeighbors(row, column);\n\t\tboolean newVal = oldVal;\n\t\tif (oldVal) { // there is life in this cell\n\t\t\tif (numNeighbors < 2 || numNeighbors > 3)\n\t\t\t\tnewVal = false; // kill it!\n\t\t} else { // oldVal == false, there is no life in this cell\n\t\t\tif (numNeighbors == 3)\n\t\t\t\tnewVal = true; // A cell is born\n\t\t}\n\t\tnewMatrix.setCellValue(row, column, newVal);\n\t}", "void editCell(Coord coord, String string);", "private boolean update_cell(int row, int col) {\n if (this.cells[row][col].hasNumericValue()) {\n int val = (int)this.cells[row][col].getValue()+1;\n this.cells[row][col].setValue((char)val);\n return true;\n }\n return false;\n }", "public void setCellValue(int rowNum, int columnNum, Cell value) {\n\t\tcells[rowNum][columnNum] = value;\n\t}", "public void setPos(int r, int c) { _row = r; _col = c; }", "void setColumnValue(int colIndex, Object value);", "public void set(int x, int y, int elem){\n matriz[x][y] = elem;\n }", "public void setValueAt(Object value, int row, int col) {\n if (rows != null && row >=0 && row < rows.size()) {\n PredefinedAttributeRow singleRow = (PredefinedAttributeRow) rows.get(row);\n if (singleRow != null) {\n switch (col) {\n case iColName:\n singleRow.setName((String) value); \n break;\n case iColIncluded:\n singleRow.setIncluded((String) value); \n break;\n case iColRequired:\n singleRow.setRequired((String) value); \n default:\n return;\n }\n }\n fireTableCellUpdated(row, col);\n }\n }", "public void setState(int row, int col) throws ArrayIndexOutOfBoundsException {\r\n board[row][col] = currentPlayer;\r\n }", "protected abstract void setCell(int x, int y, boolean state);", "@Override\n public void setValueAt(Object aValue, int rowIndex, int columnIndex) {\n }", "public void set(int r, int c, int val) {\n\t\tif (board[r][c] != 0) {\n throw new IllegalStateException(\"Attempted to set(\" + r + \", \" + c + \", \" + val\n + \"), but that board position already has the non-zero value \" + board[r][c]);\n }\n\t\t\n int old = board[r][c];\n\t\tboard[r][c] = val;\n\n\t\tint diff = val - old;\n\t\trowSum[r] += diff;\n\t\tcolSum[c] += diff;\n\t\tif (r == c) {\n\t\t\tdiagSum[0] += diff;\n\t\t}\n\t\tif (r == 2 - c) {\n\t\t\tdiagSum[1] += diff;\n\t\t}\n\t}", "@Override\n public void setValueAt (Object value, int row, int col) {\n SecurityRow secRow = allSecurities.get(row);\n if (col == NEW_PRICE_COLUMN) {\n if(value==null) {\n secRow.newPrice = null;\n } else if(value instanceof Double) {\n secRow.newPrice = (Double)value;\n } else {\n double d = StringUtils.parseRate(String.valueOf(value), decimalChar);\n secRow.newPrice = d==0 ? null : d;\n }\n fireTableCellUpdated (row, col);\n }\n }", "public void setByte(byte data, int row, int column) {\n\t\tcolumns[column].setByte(data, subset[row]);\n\t}", "public NNMatrix setColumnValue(int column, double value) {\n final NNMatrix A = copy();\n final int size = numRows();\n for (int i = 0; i < size; i++) {\n A.set(i, column, value);\n }\n return A;\n }", "int changeTile(int column, char playerChar) throws ColumnFullException {\n int line;\n if(column == 0 || column > this.columns|| !this.columnIsFree(column)) throw new ColumnFullException(\"Column full\");\n else{\n line = insertOnColumn(column,playerChar);\n }\n\n return line;\n }", "@Override\n\tpublic void setValueAt(Object aValue, int rowIndex, int columnIndex) {\n\t\t\n\t}", "public void setRow(int row)\n\t{\n\t\tthis.row = row;\n\t}", "public void setRow(int row)\n\t{\n\t\tthis.row = row;\n\t}", "@Override\r\n\tpublic void setValueAt(Object aValue, int rowIndex, int columnIndex) {\n\t\t\r\n\t}", "public abstract Piece setLocation(int row, int column);", "@Override\n\tpublic void setValueAt(Object value, int row, int column) {\n\t\tElectrodomestico elecAct;\n\t\telecAct = (Electrodomestico)(elec.get(row));\n\t\tswitch(column)\n\t\t{\n\t\tcase 0://ID\n\t\t\telecAct.setId(((Integer)value).intValue());\n\t\t\tbreak;\n\t\tcase 1://Class\n\t\t\t\n\t\t\tbreak;\n\t\tcase 2://Color\n\t\t\telecAct.setColor(new Color((String)value));\n\t\t\tbreak;\n\t\tcase 3://Consumo\n\t\t\telecAct.setConsumo(new ConsumoEnergetico((char)value));\n\t\t\tbreak;\n\t\tcase 4://Peso\n\t\t\telecAct.setPeso((double)value);\n\t\t\tbreak;\n\t\tcase 5://Carga (Lavarropas)\n\t\t\t((Lavarropas)elecAct).setCarga((double)value);;\n\t\t\tbreak;\n\t\tcase 6://Resolucion (Televisor)\n\t\t\t((Television)elecAct).setResolucion(((Integer)value).intValue());\n\t\t\tbreak;\n\t\tcase 7://Sintonizador (Televisor)\n\t\t\t((Television)elecAct).setSintonizador((boolean)value);\n\t\t\tbreak;\n\t\tcase 8://Precio\n\t\t\telecAct.setPrecioBase((double)value);\n\t\t\tbreak;\n\t\tdefault:\n\t\t\tbreak;\n\t\t}\n\t\tTableModelEvent evento = new TableModelEvent(this, row, row, column);\n\t\taviso(evento);\n\t}", "public void setCellInBoard(int row, int column, char type) {\n this.myMatrix[row][column] = type;\n }", "public void setRow(int row) {\n\t\tthis.row = row; \n\t}", "public void setRow(int r) {\n\t\tthis.row = r;\n\t}", "@Override\n\tpublic void setValueAt(Object aValue, int rowIndex, int columnIndex) {\n\n\t}", "public void setCellUsed(int row, int col, boolean val) {\n used[row][col] = val;\n }" ]
[ "0.75165504", "0.7485203", "0.73901504", "0.7365078", "0.7318909", "0.72994983", "0.7285391", "0.72374296", "0.7224305", "0.72055596", "0.72041637", "0.71575785", "0.71383566", "0.71347356", "0.7117917", "0.7112204", "0.7071588", "0.7070225", "0.7056121", "0.70558506", "0.7048317", "0.7044302", "0.7015436", "0.6997384", "0.69768196", "0.6976556", "0.6959997", "0.695352", "0.6941734", "0.69363487", "0.6931385", "0.6923945", "0.68855596", "0.6882221", "0.68733776", "0.6846007", "0.68280786", "0.68183035", "0.6800125", "0.6777572", "0.67642975", "0.6723801", "0.67062014", "0.6683837", "0.6674661", "0.6670812", "0.6655367", "0.66551584", "0.6650859", "0.66461", "0.6624731", "0.66146255", "0.66137", "0.6610971", "0.6578987", "0.65744555", "0.6549277", "0.65323263", "0.6527888", "0.65166295", "0.65053535", "0.649127", "0.6456359", "0.6455767", "0.6452486", "0.6441749", "0.64382", "0.6427423", "0.64177966", "0.6407543", "0.63885766", "0.63707805", "0.6357223", "0.6345195", "0.6344153", "0.63207436", "0.63053703", "0.6303196", "0.6298434", "0.6289578", "0.6286886", "0.6280188", "0.6278576", "0.62679654", "0.6258821", "0.62576586", "0.6254459", "0.6249281", "0.6245508", "0.6237481", "0.6226944", "0.6226944", "0.6216901", "0.6207114", "0.62070674", "0.6188251", "0.6181602", "0.6177512", "0.61770874", "0.61727923" ]
0.6644618
50
the 1st name column cannot be edited
public boolean isCellEditable(int row, int col) { return col != 0; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private static String getEditingOnColumn (String windowName2) {\n\t\tString editColumn = \"\";\r\n\t\tVector<WindowTableModelMapping> maps = getMapColumns(windowName2);\r\n\t\teditColumn = editColumn +\"public boolean isCellEditable(int row, int col) {\\n\";\r\n\t\tfor (int i = 0; i < maps.size(); i++) {\r\n\t\t\tWindowTableModelMapping mp = maps.get(i);\r\n\t\t\r\n\t\t\tif(mp.IsCombobox()) {\r\n\t\t\teditColumn = editColumn +\"\tif(col == \"+i+\" )\\n\";\r\n\t\t\teditColumn = editColumn +\"\t\treturn true;\\n\";\r\n\t\t\t}\r\n\t\t\t\t\r\n\t\t\t}\r\n\t\teditColumn = editColumn + \" return false;\\n}\\n\\n\\n\";\r\n\t\treturn editColumn;\r\n\t\t}", "protected void checkColumn(int column) {\n\tif (column < 0 || column >= columns) throw new IndexOutOfBoundsException(\"Attempted to access \"+toStringShort()+\" at column=\"+column);\n}", "boolean checkNoDuplicateFields() {\n\t if (duplicateNames == null | duplicateNames.isEmpty())\n\t return true;\n\t Iterator iter = duplicateNames.iterator();\n\t String names = \"\";\n\t while (iter.hasNext()) {\n\t names = names + iter.next(); \n\t }\n\t cat.error(loc,DUPLICATE_COLUMN_NAMES,new Object[] {names});\n\t return false;\n\t }", "public void setEditable(){\r\n treatmentTabletv.setEditable(true);\r\n //treatment id editable\r\n treatmentIDColumn.setEditable(true);\r\n treatmentIDColumn.setCellFactory(TextFieldTableCell.forTableColumn());\r\n treatmentIDColumn.setOnEditCommit(new EventHandler<TableColumn.CellEditEvent<treatment, String>>() {\r\n @Override\r\n public void handle(TableColumn.CellEditEvent<treatment, String> t){\r\n treatment tm = ((treatment) t.getTableView().getItems().get(t.getTablePosition().getRow()));\r\n //if text field is left empty, show error\r\n if (t.getNewValue().length() == 0){\r\n dataRefresh();\r\n Notifications.create().title(\"Error Updating Treatment ID\")\r\n .text(\"Treatment ID text field is empty. Text fields may not be left empty. Please insert a valid Treatment ID that does not already exist!!\")\r\n .showError();\r\n }\r\n //if Treatment ID is a duplicate, show error\r\n else if (checkDuplicate(t.getNewValue())){\r\n dataRefresh();\r\n Notifications.create().title(\"Duplicate Error Updating Treatment ID\")\r\n .text(\"Treatment ID already exists. Please insert a valid Treatment ID that does not already exist!!\")\r\n .showError();\r\n }\r\n //else update treatment ID\r\n else {\r\n String dataUpdate = \"update treatment set treatmentID = ? where treatmentName = ? \";\r\n try {\r\n ps = mysql.prepareStatement(dataUpdate);\r\n ps.setString(1, t.getNewValue());\r\n ps.setString(2, tm.getTreatmentNameProperty());\r\n ps.executeUpdate();\r\n ps.close();\r\n ps = null;\r\n\r\n } catch (SQLException e) {\r\n e.printStackTrace();\r\n //maybe add an exception code here\r\n }\r\n tm.setIdProperty(t.getNewValue());\r\n }\r\n }\r\n\r\n });\r\n //treatmentName editable\r\n treatmentNameColumn.setEditable(true);\r\n treatmentNameColumn.setCellFactory(TextFieldTableCell.forTableColumn());\r\n treatmentNameColumn.setOnEditCommit(new EventHandler<TableColumn.CellEditEvent<treatment, String>>() {\r\n @Override\r\n public void handle(TableColumn.CellEditEvent<treatment, String> t){\r\n treatment tm = ((treatment) t.getTableView().getItems().get(t.getTablePosition().getRow()));\r\n //if text field is left empty, show error\r\n if (t.getNewValue().length() == 0){\r\n dataRefresh();\r\n Notifications.create().title(\"Error Updating Treatment Name\")\r\n .text(\"Treatment Name text field is empty. Text fields may not be left empty. Please insert a valid Treatment Name!\")\r\n .showError();\r\n }\r\n else {\r\n String dataUpdate = \"update treatment set treatmentName = ? where treatmentID = ? \";\r\n try {\r\n ps = mysql.prepareStatement(dataUpdate);\r\n ps.setString(1, t.getNewValue());\r\n ps.setString(2, tm.getIdProperty());\r\n ps.executeUpdate();\r\n ps.close();\r\n ps = null;\r\n\r\n } catch (SQLException e) {\r\n e.printStackTrace();\r\n //maybe add an exception code here\r\n }\r\n tm.setTreatmentNameProperty(t.getNewValue());\r\n }\r\n }\r\n });\r\n //medicine id editable\r\n medicineIDColumn.setEditable(true);\r\n medicineIDColumn.setCellFactory(TextFieldTableCell.forTableColumn());\r\n medicineIDColumn.setOnEditCommit(new EventHandler<TableColumn.CellEditEvent<treatment, String>>() {\r\n\r\n @Override\r\n public void handle(TableColumn.CellEditEvent<treatment, String> t){\r\n treatment tm = ((treatment) t.getTableView().getItems().get(t.getTablePosition().getRow()));\r\n //if text field is left empty, show error\r\n if (t.getNewValue().length() == 0){\r\n dataRefresh();\r\n Notifications.create().title(\"Error Updating Treatment's Medicine ID\")\r\n .text(\"Treatment's Medicine ID text field is empty. Text fields may not be left empty. Please insert a valid Treatment's Medicine ID!\")\r\n .showError();\r\n }\r\n /*\r\n else if (checkDuplicate(t.getNewValue())){\r\n dataRefresh();\r\n Notifications.create().title(\"Duplicate Error Updating Treatment ID\")\r\n .text(\"Treatment ID already exists. Please insert a valid Treatment ID that does not already exist!!\")\r\n .showError();\r\n }\r\n */\r\n //else update medicine id\r\n else {\r\n String dataUpdate = \"update treatment set medicineID = ? where treatmentID = ? \";\r\n try {\r\n ps = mysql.prepareStatement(dataUpdate);\r\n ps.setString(1, t.getNewValue());\r\n ps.setString(2, tm.getIdProperty());\r\n ps.executeUpdate();\r\n ps.close();\r\n ps = null;\r\n\r\n } catch (SQLException e) {\r\n e.printStackTrace();\r\n //maybe add an exception code here\r\n }\r\n tm.setMedicineIDProperty(t.getNewValue());\r\n }\r\n\r\n }\r\n });\r\n\r\n //department id editable\r\n departmentIDColumn.setEditable(true);\r\n departmentIDColumn.setCellFactory(TextFieldTableCell.forTableColumn());\r\n departmentIDColumn.setOnEditCommit(new EventHandler<TableColumn.CellEditEvent<treatment, String>>() {\r\n\r\n @Override\r\n public void handle(TableColumn.CellEditEvent<treatment, String> t){\r\n treatment tm = ((treatment) t.getTableView().getItems().get(t.getTablePosition().getRow()));\r\n //if text field is left empty, show error\r\n if (t.getNewValue().length() == 0){\r\n dataRefresh();\r\n Notifications.create().title(\"Error Updating Treatment's Department ID\")\r\n .text(\"Treatment's Department ID text field is empty. Text fields may not be left empty. Please insert a valid Treatment Department ID!\")\r\n .showError();\r\n }\r\n /*\r\n else if (checkDuplicate(t.getNewValue())){\r\n dataRefresh();\r\n Notifications.create().title(\"Duplicate Error Updating Treatment's ID\")\r\n .text(\"Treatment ID already exists. Please insert a valid Treatment ID that does not already exist!!\")\r\n .showError();\r\n }\r\n */\r\n //else update department ID\r\n else {\r\n String dataUpdate = \"update treatment set departmentID = ? where treatmentID = ? \";\r\n try {\r\n ps = mysql.prepareStatement(dataUpdate);\r\n ps.setString(1, t.getNewValue());\r\n ps.setString(2, tm.getIdProperty());\r\n ps.executeUpdate();\r\n ps.close();\r\n ps = null;\r\n\r\n } catch (SQLException e) {\r\n e.printStackTrace();\r\n //maybe add an exception code here\r\n }\r\n tm.setDepartmentIDProperty(t.getNewValue());\r\n }\r\n\r\n }\r\n });\r\n //disease id editable\r\n diseaseIDColumn.setEditable(true);\r\n diseaseIDColumn.setCellFactory(TextFieldTableCell.forTableColumn());\r\n diseaseIDColumn.setOnEditCommit(new EventHandler<TableColumn.CellEditEvent<treatment, String>>() {\r\n\r\n @Override\r\n public void handle(TableColumn.CellEditEvent<treatment, String> t){\r\n treatment tm = ((treatment) t.getTableView().getItems().get(t.getTablePosition().getRow()));\r\n //if text field is left empty, show error\r\n if (t.getNewValue().length() == 0){\r\n dataRefresh();\r\n Notifications.create().title(\"Error Updating Treatment's Disease ID\")\r\n .text(\"Treatment's Disease ID text field is empty. Text fields may not be left empty. Please insert a valid Treatment Disease ID!\")\r\n .showError();\r\n }\r\n /*\r\n else if (checkDuplicate(t.getNewValue())){\r\n dataRefresh();\r\n Notifications.create().title(\"Duplicate Error Updating Treatment ID\")\r\n .text(\"Treatment ID already exists. Please insert a valid Treatment ID that does not already exist!!\")\r\n .showError();\r\n }\r\n */\r\n //else update disease ID\r\n else {\r\n String dataUpdate = \"update treatment set diseaseID = ? where treatmentID = ? \";\r\n try {\r\n ps = mysql.prepareStatement(dataUpdate);\r\n ps.setString(1, t.getNewValue());\r\n ps.setString(2, tm.getIdProperty());\r\n ps.executeUpdate();\r\n ps.close();\r\n ps = null;\r\n\r\n } catch (SQLException e) {\r\n e.printStackTrace();\r\n //maybe add an exception code here\r\n }\r\n tm.setDiseaseIDProperty(t.getNewValue());\r\n }\r\n }\r\n });\r\n }", "public String getDuplicateUpdateColumnString() {\n return null;\n }", "boolean editEntry(String id, String val, String colName) throws Exception;", "@Override\n\tpublic void validateHeaderColumns() {\n\t\tString assigned = getAssignedVolunteers();\n\t\tif (!\"TotalVolunteerAssignments\".equals(assigned)) {\n\t\t\tthrow new IllegalStateException(\n\t\t\t\t\t\"The total volunteer assignments column has changed. It is now showing as \" + assigned\n\t\t\t\t\t\t\t+ \". Please update VolunteerDashboardRow\");\n\t\t}\n\t\tString unassigned = getUnassignedVolunteers();\n\t\tif (!\"UnassignedApplicants\".equals(unassigned)) {\n\t\t\tthrow new IllegalStateException(\n\t\t\t\t\t\"The unassigned applicants column has changed. It is now showing as \" + unassigned\n\t\t\t\t\t\t\t+ \". Please update VolunteerDashboardRow\");\n\t\t}\n\t}", "@Test\n public void testNonStringIdentifier() {\n JXTable table = new JXTable(0, 2);\n table.getColumn(0).setIdentifier(new Object());\n table.setColumnControlVisible(true);\n table.getColumnControl();\n }", "@Override\n\tprotected String getColumn()\n\t{\n\t\treturn null;\n\t}", "public int getColumnIndex() {\n/* 2979 */ throw new RuntimeException(\"Stub!\");\n/* */ }", "public static String wrongPick() {\n return \"Wrong column or row picked!\";\n }", "private void edit() {\r\n if (String.valueOf(txt_name.getText()).equals(\"\") || String.valueOf(txt_bagian.getText()).equals(\"\")|| String.valueOf(txt_address.getText()).equals(\"\")|| String.valueOf(txt_telp.getText()).equals(\"\")) {\r\n Toast.makeText(getApplicationContext(),\r\n \"Anda belum memasukan Nama atau ALamat ...\", Toast.LENGTH_SHORT).show();\r\n } else {\r\n SQLite.update(Integer.parseInt(txt_id.getText().toString().trim()),txt_name.getText().toString().trim(),\r\n txt_bagian.getText().toString().trim(),\r\n txt_address.getText().toString().trim(),\r\n txt_telp.getText().toString().trim());\r\n Toast.makeText(getApplicationContext(),\"Data berhasil di Ubah\",Toast.LENGTH_SHORT).show();\r\n blank();\r\n finish();\r\n }\r\n }", "@Override\n public void alterColumnByName(String name, XPropertySet descriptor) throws SQLException, NoSuchElementException {\n \n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {//C.P.M le decimos que no seran editables los componetnes\r\n return false;\r\n }", "public void testEditBooleanCellWithOtherColumnOnSameFeatureName() throws Exception {\n final UITableRepresentation table = localSession.getLocalSessionBrowser().perCategory().selectViewpoint(\"read_only_column\").selectRepresentation(\"read_only_column\")\n .selectRepresentationInstance(\"new read_only_column\", UITableRepresentation.class).open();\n // Get the second line, which is actually the first sub-line of the first top-level line.\n SWTBotTreeItem[] items = table.getTable().getAllItems()[0].getItems();\n\n // Check the values before.\n assertEquals(\"newEReference1 : B0\", items[0].cell(0));\n assertEquals(\"false\", items[0].cell(1));\n assertEquals(\"false\", items[0].cell(2));\n\n pressKey(table.getTable(), \"arrow_down\");\n pressKey(table.getTable(), \"arrow_down\");\n pressKey(table.getTable(), \"arrow_right\");\n pressKey(table.getTable(), \"space\");\n\n table.getTable().display.syncExec(new Runnable() {\n public void run() {\n table.getTable().widget.update();\n }\n });\n \n // Check the values after: no change expected, the column through which we tried to do the edition has canEdit = <%false%>\n assertEquals(\"newEReference1 : B0\", items[0].cell(0));\n assertEquals(\"false\", items[0].cell(1));\n assertEquals(\"false\", items[0].cell(2));\n\n }", "void checkType(int i, DataType.Name name) {\n DataType defined = getType(i);\n if (name != defined.getName())\n throw new InvalidTypeException(String.format(\"Column %s is of type %s\", getName(i), defined));\n }", "@Override\r\n public int getColumnCount() {\n return fixColumNames.length;\r\n }", "boolean canEditValueOfColumn(ModelColumnInfo<Item> column);", "@Override\n public boolean isCellEditable(int row, int column) {\n return false;\n }", "@Override\n\t\t\tpublic boolean isCellEditable(int row, int column) {\n\t\t\t\t// khong cho chinh sua column 3 return column !=3\n\n\t\t\t\t// khong cho chinh sua\n\t\t\t\treturn false;\n\t\t\t}", "@Override\n public boolean isCellEditable(int rowIndex, int columnIndex) {\n return columnIndex == 1;\n }", "@Override\n public int getColumnCount() {\n return 2;\n }", "@Override\n\tpublic int getColumnCount() {\n\t\treturn 1;\n\t}", "@Override\n public boolean isCellEditable(int i, int i1) {\n return false;\n }", "@Override\r\n\t\t\t\t public boolean isCellEditable(int row, int column) {\n\t\t\t\t return column == 3 || column == 4;\r\n\t\t\t\t }", "public String getColumnNameOne(){\n return columnNameOneLbl.getText();\n }", "private void makeModifiable() {\n final TableEditor editor = new TableEditor(providers);\n editor.horizontalAlignment = SWT.LEFT;\n editor.grabHorizontal = true;\n editor.minimumWidth = 50;\n\n // editing the fourth column\n final int editable = 4;\n\n providers.addSelectionListener(new SelectionListener() {\n \n @Override\n public void widgetSelected(SelectionEvent exc) {\n\n TableItem item = (TableItem) exc.item;\n\n //Column should only be editable if arguments are allowed for the provider.\n if (item.getText(3).toString().equals(\"false\") || item == null) {\n return;\n }\n\n Control oldEditor = editor.getEditor();\n\n if (oldEditor != null) {\n oldEditor.dispose();\n }\n\n \n Text newEditor = new Text(providers, SWT.NONE);\n newEditor.setText(item.getText(editable));\n newEditor.addModifyListener(new ModifyListener() {\n\n \n @Override\n public void modifyText(ModifyEvent exc) {\n Text text = (Text) editor.getEditor();\n editor.getItem().setText(editable, text.getText());\n }\n });\n \n newEditor.selectAll();\n newEditor.setFocus();\n editor.setEditor(newEditor, item, editable); \n }\n\n @Override\n public void widgetDefaultSelected(SelectionEvent exc) {\n // TODO Auto-generated method stub\n }\n });\n \n for (int i = 0; i < TITLES.length; i++) {\n providers.getColumn(i).pack();\n }\n }", "public void alterarDadosCadastraisNomeInvalido(String nome) {\n\t\tAlterarDadosCadastraisPage alterarDadosCadastraisPage = new AlterarDadosCadastraisPage(driver);\n\t\talterarDadosCadastraisPage.getInputNome().clear();\n\t\talterarDadosCadastraisPage.getInputNome().sendKeys(nome);\n\t\talterarDadosCadastraisPage.getButtonSalvar().click();\n\t}", "@Override\n\tpublic void changedUpdate(DocumentEvent e) {\n\t\tvalidateNameField();\n\t}", "private boolean noConflictInColumn(int columnIndex, int number) {\n for (int i = 0; i < 9; i++) {\n if (grid[i][columnIndex] == number) {\n return false;\n }\n }\n return true;\n }", "private void edit() {\n if (String.valueOf(tgl_pengobatanField.getText()).equals(null)\n || String.valueOf(waktu_pengobatanField.getText()).equals(null)) {\n Toast.makeText(getApplicationContext(),\n \"Ada Yang Belum Terisi\", Toast.LENGTH_SHORT).show();\n } else {\n SQLite.update(Integer.parseInt(idField.getText().toString().trim()),nama_pasien2,nama_dokter2, tgl_pengobatanField.getText().toString().trim(),waktu_pengobatanField.getText().toString(),\n keluhan_pasienField.getText().toString().trim(),hasil_diagnosaField.getText().toString().trim(),\n biayaField.getText().toString().trim());\n blank();\n finish();\n }\n }", "@Override\n public boolean isCellEditable(int row, int col) {\n if (col == 0) return false;\n String attribute = data[row][0].toString();\n return attribute.equals(\"Description\")||\n attribute.equals(\"Generated\")||\n attribute.equals(\"Scannum\")||\n attribute.equals(\"Patient ID\")||\n attribute.equals(\"Exp Date\")||\n attribute.equals(\"Exp Time\")||\n attribute.equals(\"db_name\") ||\n attribute.equals(\"Data type string\") ||\n attribute.equals(\"History\");\n }", "@AutoEscape\n public String getModelIndexErrorPolicy();", "public void updateCantByName(int nr, String nume) {\n\t\tConnection connection = null;\n\t\tPreparedStatement st = null;\n\t\tString query = updateQuery(\"cantitate\", \"nume\");\n\t\ttry {\n\t\t\tconnection = ConnectionFactory.createCon();\n\t\t\tst = connection.prepareStatement(query);\n\t\t\tst.setInt(1, nr);\n\t\t\tst.setString(2, nume);\n\t\t\tst.executeUpdate();\n\t\t}catch(SQLException e) {\n\t\t\tLOGGER.fine(type.getName() + \"DAO:deleteByName\" + e.getMessage());\n\t\t}\n\t}", "@Override\n protected void validateColumn(WorksheetColumn worksheetColumn,\n String changedValue) {\n\t\tif (\"foo\".equals(changedValue)) {\n\t\t\tworksheetColumn.setErrorKey(\"foo.error\");\n\t\t} else {\n\t\t\tworksheetColumn.removeError();\n\t\t}\n\t}", "@Override\r\n\tprotected int[] getColumnModified(ColumnDefinition columnDefinition, DatabaseMetaData dbmd) {\n\t\treturn null;\r\n\t}", "@AutoEscape\n public String getModelIndexErrorMessage();", "public void editSelectedItem() {\n\t\tfinal ColumnInfo oldinfo = m_view.getSelectedItem();\n\t\tif (oldinfo != null) {\n\t\t\tfinal TableId tableid = m_view.getModel().getTableId();\n\t\t\tfinal TSConnection tsconn = m_view.getModel().getConnection();\n\t\t\tSQLCommandDialog dlg = SQLCommandDialog.createDialog(tsconn, true);\n\t\t\tdlg.setMessage(I18N.getLocalizedMessage(\"Modify Column\"));\n\n\t\t\tModelerFactory factory = ModelerFactory.getFactory(tsconn);\n\t\t\tfinal ColumnPanel panel = factory.createColumnPanel(tsconn, tableid, oldinfo, false);\n\t\t\tdlg.setPrimaryPanel(panel);\n\t\t\tdlg.addValidator(panel);\n\t\t\tdlg.setSize(dlg.getPreferredSize());\n\t\t\tdlg.addDialogListener(new SQLDialogListener() {\n\t\t\t\tpublic boolean cmdOk() throws SQLException {\n\t\t\t\t\tTSTable tablesrv = (TSTable) tsconn.getImplementation(TSTable.COMPONENT_ID);\n\t\t\t\t\tColumnInfo newinfo = panel.getColumnInfo();\n\t\t\t\t\ttablesrv.modifyColumn(tableid, newinfo, oldinfo);\n\t\t\t\t\treturn true;\n\t\t\t\t}\n\t\t\t});\n\t\t\tdlg.showCenter();\n\t\t\tif (dlg.isOk()) {\n\t\t\t\tSystem.out.println(\"AlterColumnsController.editSelected item: \" + tableid);\n\t\t\t\ttsconn.getModel(tableid.getCatalog()).reloadTable(tableid);\n\t\t\t\tm_view.getModel().setTableId(tableid);\n\t\t\t}\n\t\t}\n\t}", "public void editDataHeader(DataHeader header, int noCol){\n EditDataHeaderDialog editDialog = new EditDataHeaderDialog(this, dataset,header,noCol, dataset.getRight(), dataset.getWords(noCol));\n editDialog.setVisible(true);\n }", "@Test\n public void execute_invalidContactIndexFilteredList_editFailure() {\n // update Contact filtered list to contain only a single Contact\n showContactAtIndex(model, INDEX_FIRST_CONTACT);\n\n Index outOfBoundIndex = INDEX_SECOND_CONTACT;\n\n // ensures that outOfBoundIndex is still in bounds of contact list\n int contactListSize = model.getContactList().getContactList().size();\n assertTrue(outOfBoundIndex.getZeroBased() < contactListSize);\n\n EditContactDescriptor descriptor = new EditContactDescriptorBuilder().withName(VALID_NAME_BOB).build();\n EditContactCommand editContactCommand = new EditContactCommand(outOfBoundIndex, descriptor);\n\n assertCommandFailure(editContactCommand, model, Messages.MESSAGE_INVALID_CONTACT_DISPLAYED_INDEX);\n }", "private static String [] getColumnName(){\r\n\t\tString [] columnNames = { DBSAResourceBundle.res.getString(\"no\"), DBSAResourceBundle.res.getString(\"title\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"authors\"), DBSAResourceBundle.res.getString(\"link\"),\r\n\t\t\t\tDBSAResourceBundle.res.getString(\"year\"),DBSAResourceBundle.res.getString(\"abstract\"), \r\n\t\t\t\tDBSAResourceBundle.res.getString(\"publisher\"),(\"X\"), \r\n\t\t\t\t(\"duplicate\"), \"id\"};\r\n\t\t\t\r\n\t\treturn columnNames;\r\n\t}", "@Override\n public String getColumnName(int columnIndex) {\n return nomeColunas[columnIndex];\n }", "@Override\n public String getColumnName(int columnIndex) {\n return nomeColunas[columnIndex];\n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {//C.P.M no sera editable\r\n return false;\r\n }", "@Override\n public boolean isCellEditable(int row, int column) \n {\n return false;\n }", "@Override\r\n\tpublic void updateNbCol() {\r\n\t\treturn;\r\n\t}", "protected String getDefaultColumnName(int col)\r\n {\n return \"\";\r\n }", "@Test(timeout = 4000)\n public void test022() throws Throwable {\n DBColumn[] dBColumnArray0 = new DBColumn[0];\n // Undeclared exception!\n try { \n SQLUtil.renderColumnNames(dBColumnArray0);\n fail(\"Expecting exception: ArrayIndexOutOfBoundsException\");\n \n } catch(ArrayIndexOutOfBoundsException e) {\n //\n // 0\n //\n verifyException(\"org.databene.jdbacl.SQLUtil\", e);\n }\n }", "@Test(timeout = 4000)\n public void test28() throws Throwable {\n String string0 = \"+1MIm}!B_/+\";\n SQLUtil.normalize(\"+1MIm}!B_/+\", true);\n String string1 = \"call,\";\n SQLUtil.mutatesDataOrStructure(\"call,\");\n DefaultDBTable defaultDBTable0 = new DefaultDBTable();\n String string2 = \"update\";\n // Undeclared exception!\n try { \n defaultDBTable0.getColumn(\"update\");\n fail(\"Expecting exception: RuntimeException\");\n \n } catch(RuntimeException e) {\n //\n // Column 'update' not found in table 'null'\n //\n verifyException(\"org.databene.jdbacl.model.DefaultDBTable\", e);\n }\n }", "private static TextColumnBuilder getColumnByNameField(String nameField){ \n return drColumns.get(nameField);\n }", "@Override\npublic void refillColumnTitle(CompositeAdapter firstRowAdapter) {\n\t\n}", "@Override\n public boolean isCellEditable(int row, int column) {\n return false;\n }", "@Override\n public boolean isCellEditable(int row, int column) {\n return false;\n }", "public int getColumnCount() {\n/* 2881 */ throw new RuntimeException(\"Stub!\");\n/* */ }", "@Override\n public int getColChange() {\n return colChange;\n }", "private void tblEntryVetoableChange(java.beans.PropertyChangeEvent evt)throws java.beans.PropertyVetoException {\n }", "private EditableTableModel(Object[][] rowData, String[] columnName) { // constructor\n\t super(rowData, columnName);\n\t this.editable_columns = new boolean[columnName.length];\n\t Arrays.fill(editable_columns, Boolean.FALSE);\n\t }", "@Override\n public boolean isCellEditable(int rowIndex, int columnIndex)\n {\n return columnIndex == 1;\n }", "private boolean checkColNameSet() {\n return (null != colNames && colNames.size() > 0);\n }", "protected void checkRow(int row) {\n\tif (row < 0 || row >= rows) throw new IndexOutOfBoundsException(\"Attempted to access \"+toStringShort()+\" at row=\"+row);\n}", "@Override\n public int getColumnCount()\n {\n if (!UserMain.self.is_user() && !UserMain.self.is_admin())\n return col_names.length - 2;\n\n // EDIT IST 2.LAST ROW!!!!\n if (!UserMain.self.is_admin())\n return col_names.length - 1;\n\n\n return col_names.length;\n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {\n return false;\r\n }", "@Override\n\tpublic void insertUpdate(DocumentEvent e) {\n\t\tvalidateNameField();\n\t}", "public static void stinException(String nameField,Editable number) throws Exceptions {\n if(nameField.equals(\"stock\") && number.toString().isEmpty()){\n numberObtained=0;\n }\n if(nameField.equals(\"stock\") && number.toString().isEmpty()==false) {\n try {\n if (Integer.parseInt(number.toString()) < 0) {\n throw new Exceptions(\"You need to insert positive integer numbers\");\n }\n } catch (Exception e) {\n throw new Exceptions(\"Insert correctly the number of the stock\");\n }\n }\n try {\n if (nameField.equals(\"cost\") && Double.parseDouble(number.toString()) <= 0) {\n throw new Exceptions(\"You need to insert positive decimal numbers\");\n }\n }catch (Exceptions fs){\n throw new Exceptions(\"You need to insert positive decimal numbers\");\n }catch (Exception e){\n throw new Exceptions(\"The cost is a decimal number\");\n }\n\n\n }", "@Test(timeout = 4000)\n public void test112() throws Throwable {\n DBDataType dBDataType0 = DBDataType.getInstance((-280560843), \"\");\n DefaultDBColumn defaultDBColumn0 = new DefaultDBColumn(\"new org.apache.derby.catalog.TriggerOldTransitionRows() \", (DBTable) null, dBDataType0);\n DBColumn[] dBColumnArray0 = new DBColumn[4];\n dBColumnArray0[0] = (DBColumn) defaultDBColumn0;\n // Undeclared exception!\n try { \n SQLUtil.renderColumnNames(dBColumnArray0);\n fail(\"Expecting exception: NullPointerException\");\n \n } catch(NullPointerException e) {\n //\n // no message in exception (getMessage() returned null)\n //\n verifyException(\"org.databene.jdbacl.SQLUtil\", e);\n }\n }", "@Override\n public void alterColumnByIndex(int index, XPropertySet descriptor) throws SQLException, IndexOutOfBoundsException {\n \n }", "protected void editOccured(ModifyEvent e) {\n \n \t\tString aValue = text.getText();\n \t\tif (aValue == null) {\n \t\t\taValue = StringStatics.BLANK;\n \t\t}\n \t\tObject typedValue = aValue;\n \t\tboolean oldValidState = isValueValid();\n \t\tboolean newValidState = isCorrect(typedValue);\n \t\tif (typedValue == null && newValidState) {\n \t\t\tassert (false) : \"Validator isn't limiting the cell editor's type range\"; //$NON-NLS-1$\n \t\t}\n \t\tif (!newValidState) {\n \t\t\t// try to insert the current value into the error message.\n \t\t\tsetErrorMessage(\n \t\t\t\tMessageFormat.format(\n \t\t\t\t\tgetErrorMessage(),\n \t\t\t\t\tnew Object[] { aValue }));\n \t\t}\n \t\tvalueChanged(oldValidState, newValidState);\n \t}", "@Test(timeout = 4000)\n public void test025() throws Throwable {\n ConstraintDescriptorList constraintDescriptorList0 = new ConstraintDescriptorList();\n // Undeclared exception!\n try { \n SQLUtil.renderColumnNames((List<DBColumn>) constraintDescriptorList0);\n fail(\"Expecting exception: IndexOutOfBoundsException\");\n \n } catch(IndexOutOfBoundsException e) {\n //\n // Index: 0, Size: 0\n //\n verifyException(\"java.util.ArrayList\", e);\n }\n }", "void disableEdit() {\n\t\tnameField.setEditable(false);\n\t\tssnField.setEditable(false);\n\t\ttakenDateField.setEditable(false);\n\t\ttotalScoreField.setEditable(false);\n\t\tadvisorField.setEditable(false);\n\t\t\n\t}", "@Test(timeout = 4000)\n public void test57() throws Throwable {\n ConstraintDescriptorList constraintDescriptorList0 = new ConstraintDescriptorList();\n DefaultDBColumn defaultDBColumn0 = new DefaultDBColumn(\"wrong^chfcksum\", (DBTable) null, (-1877), \"wrong^chfcksum\");\n constraintDescriptorList0.add((Object) defaultDBColumn0);\n constraintDescriptorList0.add((Object) defaultDBColumn0);\n String string0 = SQLUtil.renderColumnNames((List<DBColumn>) constraintDescriptorList0);\n assertEquals(\"wrong^chfcksum, wrong^chfcksum\", string0);\n }", "@Override\n public int getColumnCount() {\n return columname.length;\n \n }", "public void beforeEdit(Librerias.ZafTblUti.ZafTblEvt.ZafTableEvent evt) {\n// strEstCncDia=tblDat.getValueAt(tblDat.getSelectedRow(), INT_TBL_DAT_EST_CON)==null?\"\":tblDat.getValueAt(tblDat.getSelectedRow(), INT_TBL_DAT_EST_CON).toString();\n// if(strEstCncDia.equals(\"S\")){\n// mostrarMsgInf(\"<HTML>La cuenta ya fue conciliada.<BR>Desconcilie la cuenta en el documento a modificar y vuelva a intentarlo.</HTML>\");\n//// fireAsiDiaListener(new ZafAsiDiaEvent(this), INT_BEF_EDI_CEL);\n// objTblCelEdiTxtVcoCta.setCancelarEdicion(true);\n// }\n// else if(strEstCncDia.equals(\"B\")){\n// mostrarMsgInf(\"<HTML>No se puede cambiar el valor de la cuenta<BR>Este valor proviene de la transferencia ingresada.</HTML>\");\n// objTblCelEdiTxtVcoCta.setCancelarEdicion(true);\n// }\n// else{\n// //Permitir de manera predeterminada la operaci�n.\n// blnCanOpe=false;\n// //Generar evento \"beforeEditarCelda()\".\n// fireAsiDiaListener(new ZafAsiDiaEvent(this), INT_BEF_EDI_CEL);\n// //Permitir/Cancelar la edici�n de acuerdo a \"cancelarOperacion\".\n// if (blnCanOpe)\n// {\n// objTblCelEdiTxtVcoCta.setCancelarEdicion(true);\n// }\n// }\n }", "private void editName() {\n Routine r = list.getSelectedValue();\n\n String s = (String) JOptionPane.showInputDialog(\n this,\n \"Enter the new name:\",\n \"Edit name\",\n JOptionPane.PLAIN_MESSAGE,\n null, null, r.getName());\n\n if (s != null) {\n r.setName(s);\n }\n }", "@Override\n\tpublic void cancelCellEditing() {\n\t\tlog.info(\"|------表格单元格编辑模型------|\\t\"+\"cancelCellEditing\\t\");\n\t}", "private void hideColumn() {\n remindersTable.getColumnModel().getColumn(0).setMinWidth(0);\n remindersTable.getColumnModel().getColumn(0).setMaxWidth(0);\n remindersTable.getColumnModel().getColumn(0).setWidth(0);\n }", "@Test(timeout = 4000)\n public void test061() throws Throwable {\n ConstraintDescriptorList constraintDescriptorList0 = new ConstraintDescriptorList();\n // Undeclared exception!\n try { \n SQLUtil.renderColumnNames((List<DBColumn>) constraintDescriptorList0);\n fail(\"Expecting exception: IndexOutOfBoundsException\");\n \n } catch(IndexOutOfBoundsException e) {\n //\n // Index: 0, Size: 0\n //\n verifyException(\"java.util.ArrayList\", e);\n }\n }", "private boolean row_number_error(int min, int max) {\n int row_size = getHighlightedRows() / 2;\n if ( (min <= row_size) && (row_size <= max))\n return false;\n String dup = (min > 1)? \"s\": \"\";\n if (min > row_size) {\n String status = \"Please select at least \" + min + \" meaning\" + dup;\n statusView.setText(status);\n } else if (row_size > max) {\n String status = (max > min)? \"Please select between \" + min + \" and \" + max + \" meanings\":\n \"Please select \" + min + \" meaning\" + dup;\n statusView.setText(status);\n }\n return true;\n }", "@Override\n public int getColumnCount() { return columnnames.length; }", "@FXML\n \tprivate void validationNameEdit(ActionEvent event) {\n\n \t\tnameEditText.setDisable(!nameEditText.isDisable());\n \t\tnameEditText.setText(ns.getCurrentSystem().getName());\n \t\t\n \t}", "@Override\n public boolean isCellEditable(int row, int col) {\n return col == 2;\n }", "@FXML\r\n private void bRem() throws SQLException {\n int index = tableView.getSelectionModel().getSelectedIndex();\r\n if(index>=0)\r\n {\r\n calc calc = data.get(index);\r\n String tmp = calc.getComment();\r\n try{\r\n UpdateDb(tmp.substring(0,tmp.lastIndexOf(\"\\n\")), calc.getDate());\r\n }catch (StringIndexOutOfBoundsException e)\r\n {\r\n UpdateDb(\"\", calc.getDate());\r\n }\r\n refresh();\r\n }else\r\n {\r\n Alert alert = new Alert(Alert.AlertType.ERROR);\r\n alert.setTitle(\"ERROR\");\r\n alert.setContentText(\"Nothing Selected!!!\");\r\n alert.showAndWait();\r\n }\r\n }", "@Test(timeout = 4000)\n public void test022() throws Throwable {\n DBColumn[] dBColumnArray0 = new DBColumn[1];\n // Undeclared exception!\n try { \n SQLUtil.renderColumnNames(dBColumnArray0);\n fail(\"Expecting exception: NullPointerException\");\n \n } catch(NullPointerException e) {\n //\n // no message in exception (getMessage() returned null)\n //\n verifyException(\"org.databene.jdbacl.SQLUtil\", e);\n }\n }", "int getColumnIndex(String name);", "private boolean tableDataValid()\r\n {\r\n // if there are any form level validations that should go there\r\n int rowTotal = tblProtoCorresp.getRowCount();\r\n int colTotal = tblProtoCorresp.getColumnCount();\r\n for (int rowIndex = 0; rowIndex < rowTotal ; rowIndex++)\r\n {\r\n for (int colIndex = 0; colIndex < colTotal; colIndex++)\r\n {\r\n TableColumn column = codeTableColumnModel.getColumn(colIndex) ;\r\n\r\n ColumnBean columnBean = (ColumnBean)column.getIdentifier() ;\r\n\r\n if (columnBean.getColumnEditable()\r\n && !columnBean.getColumnCanBeNull())\r\n {\r\n if ( tblProtoCorresp.getValueAt(rowIndex,colIndex) != null)\r\n {\r\n if (tblProtoCorresp.getValueAt(rowIndex,colIndex).equals(\"\")\r\n || tblProtoCorresp.getValueAt(rowIndex,colIndex).toString().trim().equals(\"\") )\r\n {\r\n String msg = coeusMessageResources.parseMessageKey(\r\n \"checkInputValue_exceptionCode.2402\");\r\n String msgColName = \" \" + columnBean.getDisplayName() + \". \";\r\n CoeusOptionPane.showInfoDialog(msg + msgColName);\r\n tblProtoCorresp.changeSelection(rowIndex, colIndex, false, false) ;\r\n return false;\r\n }\r\n }\r\n else\r\n {\r\n String msg = coeusMessageResources.parseMessageKey(\r\n \"checkInputValue_exceptionCode.2402\");\r\n\r\n String msgColName = \" \" + columnBean.getDisplayName() + \". \";\r\n CoeusOptionPane.showInfoDialog(msg + msgColName);\r\n tblProtoCorresp.changeSelection(rowIndex, colIndex, false, false) ;\r\n return false;\r\n }\r\n }\r\n }\r\n\r\n }\r\n return true ;\r\n }", "@Override\n public boolean isCellEditable(int arg0, int arg1) {\n return false;\n }", "@Override\n public boolean isCellEditable(int arg0, int arg1) {\n return false;\n }", "@Override\n public String getColumnName(int column) {\n if (column == COL_ID) {\n return \"Código\";\n } else if (column == COL_NAME) {\n return \"Nome\";\n }\n return \"\";\n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {\r\n return false;\r\n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {\r\n return false;\r\n }", "@Override\r\n public boolean isCellEditable(int rowIndex, int vColIndex) {\r\n return false;\r\n }", "private void setColumnName(ResultSetMetaData metadata) throws SQLException {\r\n if (connectedToDatabase) {\r\n for (int i = 1; i <= numberOfcolumns; i++) {\r\n columnNames.add(i - 1, metadata.getColumnName(i));\r\n }\r\n /**\r\n * create new column to handle status of row. You can hide or visible it by comment or not the line code follow.\r\n */\r\n //columnNames.add(\"RecordStatus\");\r\n }\r\n }", "@DefaultMessage(\"Please enter a unique value for this field\")\n @Key(\"gen.fieldUniqueOnlyException\")\n String gen_fieldUniqueOnlyException();", "public void setColumnName(String newVal) {\n if ((newVal != null && this.columnName != null && (newVal.compareTo(this.columnName) == 0)) || \n (newVal == null && this.columnName == null && columnName_is_initialized)) {\n return; \n } \n this.columnName = newVal; \n\n columnName_is_modified = true; \n columnName_is_initialized = true; \n }", "public void actionPerformed(ActionEvent arg0) {\n\t\t\t\tString nombre=JOptionPane.showInputDialog(\"Digite el nuevo Nombre:\");\r\n\t\t\t\tint edad=Integer.parseInt(JOptionPane.showInputDialog(\"Digite el nuevo Edad:\"));\r\n\t\t\t\tString direccion=JOptionPane.showInputDialog(\"Digite el nuevo Direccion:\");\r\n\t\t\t\tString seccion=JOptionPane.showInputDialog(\"Digite el nuevo Seccion:\");\r\n\t\t\t\t\r\n\t\t\t\tBaseConeccion diegoConexion = new BaseConeccion();\r\n\t\t\t\tConnection pruebaCn=diegoConexion.getConexion();\r\n\t\t\t\tStatement s;\r\n\t\t\t\tint rs;\r\n\t\t\t\t\r\n\t\t\t\tString requisito=null;\r\n\t\t\t\tint num1=table_1.getSelectedColumn();\r\n\t\t\t\tint num2=table_1.getSelectedRow();\r\n\t\t\t\t\r\n\t\t\t\trequisito=\"update alumno set nombre='\"+nombre+\"', edad=\"+edad+\", direccion='\"+direccion+\"', seccion='\"+seccion+\"' where codigo='\"+table_1.getValueAt(num1, num2)+\"'\";\r\n\t\t\t\r\n\t\t\t\ttry {\r\n\t\t\t\t\ts=(Statement)pruebaCn.createStatement();\r\n\t\t\t\t\trs=s.executeUpdate(requisito);\r\n\t\t\t\t\tJOptionPane.showMessageDialog(null, \"Alumno Modificado de la Base de Datos\");\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\t\t\r\n\t\t\t\t}catch(SQLException e1) {\r\n\t\t\t\t\te1.printStackTrace();\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t}", "@Override\n public int getColumnCount() {\n return colName.length;\n }", "@Override\n public void checkEditing() {\n }", "private boolean checkInputTableName(AccessInputMeta meta){\n if (meta.getTableName()==null || meta.getTableName().length()<1)\n {\n MessageBox mb = new MessageBox(shell, SWT.OK | SWT.ICON_ERROR );\n mb.setMessage(BaseMessages.getString(PKG, \"AccessInputDialog.TableMissing.DialogMessage\"));\n mb.setText(BaseMessages.getString(PKG, \"System.Dialog.Error.Title\"));\n mb.open(); \n\n return false;\n }\n else\n {\n \treturn true;\n }\n\t}", "@Override\n\t\t\tpublic int getColumnCount() \n\t\t\t{\n\t\t\t\treturn 2;\n\t\t\t}", "@Override\n public boolean isCellEditable(int row, int column)\n {\n return column == convertColumnIndexToModel(AssociationsTableColumnInfo.DESCRIPTION.ordinal())\n && allowSelectDisabled;\n }", "private boolean triggerValidation()\r\n {\r\n System.out.println(\"*** Validation row : \" + selRow + \" col : \" + selColumn + \" ***\") ;\r\n /*\r\n * using the colIndex u can get the column bean for that column and then depending the\r\n * datatype of the column u apply appropriate validation rules\r\n */\r\n Object newValue = ((CoeusTextField)txtCell).getText();\r\n\r\n if (!tableStructureBeanPCDR.isIdAutoGenerated()\r\n && (selColumn == tableStructureBeanPCDR.getPrimaryKeyIndex(0)))\r\n {\r\n if (checkDependency(selRow, \"\"))\r\n {\r\n if(!CheckUniqueId(newValue.toString(), selRow, selColumn))\r\n {\r\n String msg = coeusMessageResources.parseMessageKey(\r\n \"chkPKeyUniqVal_exceptionCode.2401\");\r\n\r\n CoeusOptionPane.showInfoDialog(msg);\r\n //after failure of checking, make sure selecting the failed row\r\n\r\n return false; //fail in uniqueid check\r\n }\r\n else\r\n {\r\n return true;\r\n }\r\n }\r\n else\r\n {\r\n return false;//fail in dependency check\r\n }\r\n\r\n }\r\n else\r\n {\r\n return true;\r\n }\r\n\r\n\r\n }", "private void edit() {\n\n\t}" ]
[ "0.60579574", "0.602098", "0.5966826", "0.5872984", "0.5813824", "0.57940876", "0.57451445", "0.5657512", "0.563557", "0.5630727", "0.55869937", "0.55556804", "0.55486137", "0.5522477", "0.55199677", "0.5516289", "0.5513962", "0.55083585", "0.5507524", "0.55057234", "0.55038965", "0.54904276", "0.5479446", "0.5463355", "0.5448391", "0.54320025", "0.543096", "0.5430365", "0.54245704", "0.5405341", "0.54003805", "0.5399711", "0.5394409", "0.5383936", "0.53785664", "0.5375097", "0.5373414", "0.53640324", "0.5363867", "0.53629357", "0.53564465", "0.535035", "0.535035", "0.5349389", "0.5344359", "0.5332371", "0.5322087", "0.53151506", "0.52907085", "0.5282185", "0.527933", "0.5277068", "0.5277068", "0.52683353", "0.5266018", "0.5264716", "0.52643526", "0.52620167", "0.52605325", "0.52558607", "0.525471", "0.524387", "0.52421993", "0.5229948", "0.5227019", "0.52246433", "0.5218108", "0.52178156", "0.52131176", "0.520447", "0.5200251", "0.5197975", "0.51949954", "0.5193064", "0.5190245", "0.51878124", "0.51848316", "0.5183204", "0.5176918", "0.5175395", "0.51712203", "0.51707125", "0.5165064", "0.5164407", "0.5163453", "0.5163453", "0.51610285", "0.51608014", "0.51608014", "0.51608014", "0.51522535", "0.5145407", "0.51426786", "0.5140499", "0.5140383", "0.5122814", "0.5121816", "0.5121794", "0.51182187", "0.5115566", "0.5115196" ]
0.0
-1
Initializes the controller class.
@Override public void initialize(URL url, ResourceBundle rb) { if(rateService.ratesListById("task", th.getId())==0){ rateLabel.setVisible(true); ratingId.setVisible(false); }else { System.out.println(rateService.ratesListById("task", th.getId())); ratingId.setRating(rateService.ratesListById("task", th.getId())); rateLabel.setVisible(false); ratingId.setVisible(true); } taskActionsPane.setVvalue(0); new ZoomIn(taskActionsPane).play(); task = st.getTask(th.getId()); pt = spt.getPaidTask(th.getId()); UserTask u = sut.getUserTask(UserSession.getUser_id(), task.getTaskId()); if (u.getTask() == null && u.getUser() == null) { participateButton.setVisible(true); } if (UserSession.getRole().equals("ROLE_Therapist") && task.getUser().getUserId() == UserSession.getUser_id()) { addActionBtn.setVisible(true); updateIcon.setVisible(true); deleteIcon.setVisible(true); participateButton.setVisible(false); } if (UserSession.getRole().equals("ROLE_Moderator")) { deleteIcon.setVisible(true); } int y = 0; int x = 0; List<TaskActions> taskActions; if (pt != null) { taskTitle.setText(pt.getTitle()); taskImg.setImage(pt.getImg().getImage()); taskDescription.setText(pt.getDescription()); TaskNumDays.setText(String.valueOf(pt.getNumOfDays())); // taskMinUsers.setText(String.valueOf(pt.getMinUsers())); // TaskMaxUsers.setText(String.valueOf(pt.getMaxUsers())); String date = pt.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("dd")) + " " + pt.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("MMM")) + " 20" + pt.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("YY")); taskDate.setText(date); price.setText(String.valueOf(pt.getPrice()) + "DT"); taskActions = sta.ListTaskActionsByTaskId(pt.getTaskId()); } else { taskTitle.setText(task.getTitle()); taskImg.setImage(task.getImg().getImage()); taskDescription.setText(task.getDescription()); TaskNumDays.setText(String.valueOf(task.getNumOfDays())); // taskMinUsers.setText(String.valueOf(task.getMinUsers())); // TaskMaxUsers.setText(String.valueOf(task.getMaxUsers())); String date = task.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("dd")) + " " + task.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("MMM")) + " 20" + task.getCreatedAt().toLocalDateTime().toLocalDate().format(DateTimeFormatter.ofPattern("YY")); taskDate.setText(date); taskActions = sta.ListTaskActionsByTaskId(task.getTaskId()); } for (int i = 0; i < taskActions.size(); i++) { FXMLLoader loader = new FXMLLoader(); loader.setLocation(getClass().getResource("/coheal/views/ui/frontoffice/task/TaskActionItem.fxml")); try { Pane pane = loader.load(); TaskActionItemController c = loader.getController(); c.setData(taskActions.get(i)); if (x > 1) { y++; x = 0; } if (u.getUser() != null) { System.out.println(u.getUser().getUserId()); if (UserSession.getUser_id() == u.getUser().getUserId()) { ActionGrid.add(pane, x, y); } } else if (UserSession.getRole().equals("ROLE_Therapist") && task.getUser().getUserId() == UserSession.getUser_id()) { ActionGrid.add(pane, x, y); } x++; } catch (IOException ex) { System.out.println(ex.getMessage()); } } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void initialize() {\n\t\tcontroller = Controller.getInstance();\n\t}", "public MainController() {\n\t\tcontroller = new Controller(this);\n\t}", "public abstract void initController();", "public Controller() {\n super();\n }", "public Controller() {\n super();\n }", "public Controller()\n\t{\n\n\t}", "private static CompanyController initializeController() {\n\n controller = new CompanyController();\n return controller;\n }", "public MainController() {\n initializeControllers();\n initializeGui();\n runGameLoop();\n }", "public Controller() {\n this.model = new ModelFacade();\n this.view = new ViewFacade();\n }", "public Controller()\r\n\t{\r\n\t\tview = new View();\r\n\t}", "public Controller() {\n\t\tthis(null);\n\t}", "public void init(){\n\t\t//Makes the view\n\t\tsetUpView();\n\n\t\t//Make the controller. Links the action listeners to the view\n\t\tnew Controller(this);\n\t\t\n\t\t//Initilize the array list\n\t\tgameInput = new ArrayList<Integer>();\n\t\tuserInput = new ArrayList<Integer>();\n\t\thighScore = new HighScoreArrayList();\n\t}", "private void initialize() {\n\t\tinitializeModel();\n\t\tinitializeBoundary();\n\t\tinitializeController();\n\t}", "public void init() {\n\t\tkontrolleri1 = new KolikkoController(this);\n\t}", "protected void initialize() {\n super.initialize(); // Enables \"drive straight\" controller\n }", "public Controller() {\n model = new Model();\n comboBox = new ChannelComboBox();\n initView();\n new ChannelWorker().execute();\n timer = new Timer();\n }", "protected CityController() {\r\n\t}", "public void initialize() {\n warpController = new WarpController(this);\n kitController = new KitController(this);\n crafting = new CraftingController(this);\n mobs = new MobController(this);\n items = new ItemController(this);\n enchanting = new EnchantingController(this);\n anvil = new AnvilController(this);\n blockController = new BlockController(this);\n hangingController = new HangingController(this);\n entityController = new EntityController(this);\n playerController = new PlayerController(this);\n inventoryController = new InventoryController(this);\n explosionController = new ExplosionController(this);\n requirementsController = new RequirementsController(this);\n worldController = new WorldController(this);\n arenaController = new ArenaController(this);\n arenaController.start();\n if (CompatibilityLib.hasStatistics() && !CompatibilityLib.hasJumpEvent()) {\n jumpController = new JumpController(this);\n }\n File examplesFolder = new File(getPlugin().getDataFolder(), \"examples\");\n examplesFolder.mkdirs();\n\n File urlMapFile = getDataFile(URL_MAPS_FILE);\n File imageCache = new File(dataFolder, \"imagemapcache\");\n imageCache.mkdirs();\n maps = new MapController(this, urlMapFile, imageCache);\n\n // Initialize EffectLib.\n if (com.elmakers.mine.bukkit.effect.EffectPlayer.initialize(plugin, getLogger())) {\n getLogger().info(\"EffectLib initialized\");\n } else {\n getLogger().warning(\"Failed to initialize EffectLib\");\n }\n\n // Pre-create schematic folder\n File magicSchematicFolder = new File(plugin.getDataFolder(), \"schematics\");\n magicSchematicFolder.mkdirs();\n\n // One-time migration of legacy configurations\n migrateConfig(\"enchanting\", \"paths\");\n migrateConfig(\"automata\", \"blocks\");\n migrateDataFile(\"automata\", \"blocks\");\n\n // Ready to load\n load();\n resourcePacks.startResourcePackChecks();\n }", "public ClientController() {\n }", "public Controller() {\n\t\tthis.nextID = 0;\n\t\tthis.data = new HashMap<Integer, T>();\n\t}", "public ListaSEController() {\n }", "boolean InitController();", "public MenuController() {\r\n\t \r\n\t }", "@Override\n\tprotected void initController() throws Exception {\n\t\tmgr = orderPickListManager;\n\t}", "public CustomerController() {\n\t\tsuper();\n\n\t}", "public End_User_0_Controller() {\r\n\t\t// primaryStage = Users_Page_Controller.primaryStage;\r\n\t\t// this.Storeinfo = primaryStage.getTitle();\r\n\t}", "public Controller(){\r\n\t\tthis.fabricaJogos = new JogoFactory();\r\n\t\tthis.loja = new Loja();\r\n\t\tthis.preco = 0;\r\n\t\tthis.desconto = 0;\r\n\t}", "private Controller() {\n\t\tthis.gui = GUI.getInstance();\n\t\tthis.gui.setController(this);\n\t}", "public GameController() {\r\n\t\tsuper();\r\n\t\tthis.model = Main.getModel();\r\n\t\tthis.player = this.model.getPlayer();\r\n\t\tthis.timeline = this.model.getIndefiniteTimeline();\r\n\t}", "public PlantillaController() {\n }", "public Controller() {\n\t\tplaylist = new ArrayList<>();\n\t\tshowingMore = false;\n\t\tstage = Main.getStage();\n\t}", "public IfController()\n\t{\n\n\t}", "public TournamentController()\n\t{\n\t\tinitMap();\n\t}", "public GeneralListVueController() {\n\n\t}", "private ClientController() {\n }", "public Controller()\n\t{\n\t\ttheParser = new Parser();\n\t\tstarList = theParser.getStars();\n\t\tmessierList = theParser.getMessierObjects();\n\t\tmoon = new Moon(\"moon\");\n\t\tsun = new Sun(\"sun\");\n\t\tconstellationList = theParser.getConstellations();\n\t\tplanetList = new ArrayList<Planet>();\n\t\ttheCalculator = new Calculator();\n\t\tepoch2000JD = 2451545.0;\n\t}", "private void initialiseController() \r\n {\r\n defaultVectors();\r\n if(grantsByPIForm == null) \r\n {\r\n grantsByPIForm = new GrantsByPIForm(); //(Component) parent,modal);\r\n }\r\n grantsByPIForm.descriptionLabel.setText(UnitName);\r\n grantsByPIForm.descriptionLabel.setFont(new Font(\"SansSerif\",Font.BOLD,14));\r\n queryEngine = QueryEngine.getInstance();\r\n coeusMessageResources = CoeusMessageResources.getInstance();\r\n registerComponents();\r\n try {\r\n setFormData(null);\r\n }\r\n catch(Exception e) {\r\n e.printStackTrace(System.out);\r\n }\r\n }", "public LogMessageController() {\n\t}", "public LoginPageController() {\n\t}", "public ControllerEnfermaria() {\n }", "public ProvisioningEngineerController() {\n super();\n }", "private StoreController(){}", "public GenericController() {\n }", "@Override\n\tpublic void initialize() {\n\t\tinitializeModel(getSeed());\n\t\tinitializeView();\n\t\tinitializeControllers();\n\t\t\n\t\tupdateScore(8);\n\t\tupdateNumberCardsLeft(86);\n\n\t}", "public Controller() {\n\t\tenabled = false;\n\t\tloop = new Notifier(new ControllerTask(this));\n\t\tloop.startPeriodic(DEFAULT_PERIOD);\n\t}", "public MapController() {\r\n\t}", "@Override\r\n\tpublic void initControllerBean() throws Exception {\n\t}", "private void setupController() {\n setupWriter();\n Controller controller1 = new Controller(writer);\n controller = controller1;\n }", "public WfController()\n {\n }", "public Controller() {\n\n lastSearches = new SearchHistory();\n\n }", "private ClientController(){\n\n }", "public LoginController() {\r\n }", "public PersonasController() {\r\n }", "private void initBefore() {\n // Crear Modelo\n model = new Model();\n\n // Crear Controlador\n control = new Controller(model, this);\n\n // Cargar Propiedades Vista\n prpView = UtilesApp.cargarPropiedades(FICHERO);\n\n // Restaurar Estado\n control.restaurarEstadoVista(this, prpView);\n\n // Otras inicializaciones\n }", "public StoreController() {\n }", "public ConsoleController() {\n\t\tcommandDispatch = new CommandDispatch();\n\t}", "public LoginController() {\r\n\r\n }", "public final void init(final MainController mainController) {\n this.mainController = mainController;\n }", "public SMPFXController() {\n\n }", "public Controller()\r\n {\r\n fillBombs();\r\n fillBoard();\r\n scoreBoard = new ScoreBoard();\r\n }", "public GUIController() {\n\n }", "public void init(){\n this.controller = new StudentController();\n SetSection.displayLevelList(grade_comp);\n new DesignSection().designForm(this, editStudentMainPanel, \"mini\");\n }", "public void init(final Controller controller){\n Gdx.app.debug(\"View\", \"Initializing\");\n \n this.controller = controller;\n \n //clear old stuff\n cameras.clear();\n \n //set up renderer\n hudCamera = new OrthographicCamera();\n hudCamera.setToOrtho(false, Gdx.graphics.getWidth(), Gdx.graphics.getHeight());\n \n batch = new SpriteBatch();\n igShRenderer = new ShapeRenderer();\n shapeRenderer = new ShapeRenderer();\n \n //set up stage\n stage = new Stage();\n \n //laod cursor\n cursor = new Pixmap(Gdx.files.internal(\"com/BombingGames/WurfelEngine/Core/images/cursor.png\"));\n\n controller.getLoadMenu().viewInit(this);\n \n initalized = true;\n }", "@PostConstruct\n public void init() {\n WebsocketController.getInstance().setTemplate(this.template);\n try {\n\t\t\tthis.chatController = ChatController.getInstance();\n } catch (final Exception e){\n LOG.error(e.getMessage(), e);\n }\n }", "public ControllerTest()\r\n {\r\n }", "public SearchedRecipeController() {\n }", "public FilmOverviewController() {\n }", "public CreditPayuiController() {\n\t\tuserbl = new UserController();\n\t}", "private void initComponents() {\r\n\t\temulator = new Chip8();\r\n\t\tpanel = new DisplayPanel(emulator);\r\n\t\tregisterPanel = new EmulatorInfoPanel(emulator);\r\n\t\t\r\n\t\tcontroller = new Controller(this, emulator, panel, registerPanel);\r\n\t}", "public RootLayoutController() {\n }", "public MehController() {\n updateView(null);\n }", "public Controller(int host) {\r\n\t\tsuper(host);\r\n\t}", "public WorkerController(){\r\n\t}", "public TipoInformazioniController() {\n\n\t}", "private void initializeMealsControllers() {\n trNewPetMeal = MealsControllersFactory.createTrNewPetMeal();\n trObtainAllPetMeals = MealsControllersFactory.createTrObtainAllPetMeals();\n trDeleteMeal = MealsControllersFactory.createTrDeleteMeal();\n trUpdateMeal = MealsControllersFactory.createTrUpdateMeal();\n }", "public ProductOverviewController() {\n }", "public ProduktController() {\r\n }", "public Controller(ViewIF view) {\n\t\tthis.view = view;\n\t\tthis.dao = new DAO();\n\t\tthis.stats = new Statistics(this.dao);\n\t\tthis.gameStarted = false;\n\t}", "private void initializeMedicationControllers() {\n trNewPetMedication = MedicationControllersFactory.createTrNewPetMedication();\n trObtainAllPetMedications = MedicationControllersFactory.createTrObtainAllPetMedications();\n trDeleteMedication = MedicationControllersFactory.createTrDeleteMedication();\n trUpdateMedication = MedicationControllersFactory.createTrUpdateMedication();\n }", "public PersonLoginController() {\n }", "public PremiseController() {\n\t\tSystem.out.println(\"Class PremiseController()\");\n\t}", "public TaxiInformationController() {\n }", "public LoginController() {\n\t\treadFromFile();\n\t\t// TODO Auto-generated constructor stub\n\t}", "public Controller(){\n initControl();\n this.getStylesheets().addAll(\"/resource/style.css\");\n }", "public CreateDocumentController() {\n }", "public ControllerRol() {\n }", "Main ()\n\t{\n\t\tview = new View ();\t\t\n\t\tmodel = new Model(view);\n\t\tcontroller = new Controller(model, view);\n\t}", "public Controller () {\r\n puzzle = null;\r\n words = new ArrayList <String> ();\r\n fileManager = new FileIO ();\r\n }", "public void init() {\n \n }", "public Controller() {\n\t\tdoResidu = false;\n\t\tdoTime = false;\n\t\tdoReference = false;\n\t\tdoConstraint = false;\n\t\ttimeStarting = System.nanoTime();\n\t\t\n\t\tsetPath(Files.getWorkingDirectory());\n\t\tsetSystem(true);\n\t\tsetMultithreading(true);\n\t\tsetDisplayFinal(true);\n\t\tsetFFT(FFT.getFastestFFT().getDefaultFFT());\n\t\tsetNormalizationPSF(1);\n\t\tsetEpsilon(1e-6);\n\t\tsetPadding(new Padding());\n\t\tsetApodization(new Apodization());\n\n\t\tmonitors = new Monitors();\n\t\tmonitors.add(new ConsoleMonitor());\n\t\tmonitors.add(new TableMonitor(Constants.widthGUI, 240));\n\n\t\tsetVerbose(Verbose.Log);\n\t\tsetStats(new Stats(Stats.Mode.NO));\n\t\tsetConstraint(Constraint.Mode.NO);\n\t\tsetResiduMin(-1);\n\t\tsetTimeLimit(-1);\n\t\tsetReference(null);\n\t\tsetOuts(new ArrayList<Output>());\n\t}", "public OrderInfoViewuiController() {\n\t\tuserbl = new UserController();\n\t}", "public SessionController() {\n }", "@Override\n\tprotected void setController() {\n\t\t\n\t}", "public MainFrameController() {\n }", "public LicenciaController() {\n }", "public NearestParksController() {\n this.bn = new BicycleNetwork();\n this.pf = new LocationFacade();\n // this.bn.loadData();\n }", "public MotorController() {\n\t\tresetTachometers();\n\t}", "public AwTracingController() {\n mNativeAwTracingController = nativeInit();\n }", "public Controller(IView view) {\n\t\tengine = new Engine(this);\n\t\tclock = new Clock();\n\t\tsoundEmettor = new SoundEmettor();\n\t\tthis.view = view;\n\t}", "public HomeController() {\n }", "public HomeController() {\n }" ]
[ "0.8125658", "0.78537387", "0.78320265", "0.776199", "0.776199", "0.76010174", "0.74497247", "0.7437837", "0.7430714", "0.742303", "0.74057597", "0.7341963", "0.7327749", "0.72634363", "0.72230434", "0.7102504", "0.70575505", "0.69873077", "0.69721675", "0.6944077", "0.6912564", "0.688884", "0.6881247", "0.68776786", "0.68723065", "0.6868163", "0.68672407", "0.6851157", "0.6846883", "0.6840198", "0.68382674", "0.68338853", "0.6795918", "0.67823315", "0.6766882", "0.67650586", "0.6750353", "0.6749068", "0.6745654", "0.6743223", "0.67401046", "0.6727867", "0.6723379", "0.6695514", "0.6689967", "0.66892517", "0.66791916", "0.6677345", "0.66644365", "0.6664202", "0.66616154", "0.66532296", "0.66481894", "0.6644939", "0.6639398", "0.6633576", "0.66312426", "0.662608", "0.66258574", "0.66105217", "0.6606984", "0.66024727", "0.6597095", "0.6580141", "0.65786153", "0.65752715", "0.6574144", "0.6551536", "0.655142", "0.6547574", "0.6545647", "0.6541474", "0.6529243", "0.65284246", "0.6525593", "0.6523344", "0.6519832", "0.65134746", "0.65079254", "0.6497635", "0.64952356", "0.6493943", "0.6492926", "0.6483847", "0.6483173", "0.648183", "0.6479119", "0.64789915", "0.6476928", "0.64734083", "0.6465272", "0.64616114", "0.6444024", "0.64379543", "0.6431962", "0.64292705", "0.6425357", "0.6417148", "0.6416786", "0.64161026", "0.64161026" ]
0.0
-1
IntegratingGyroscope gyro; ModernRoboticsI2cGyro modernRoboticsI2cGyro; ElapsedTime timer = new ElapsedTime(); int spikeTime = 0; / Code to run when the op mode is initialized goes here
@Override public void init() { BackRight = hardwareMap.dcMotor.get("BackRight"); BackLeft = hardwareMap.dcMotor.get("BackLeft"); FrontRight = hardwareMap.dcMotor.get("FrontRight"); FrontLeft = hardwareMap.dcMotor.get("FrontLeft"); FrontRight.setDirection(DcMotor.Direction.REVERSE); BackRight.setDirection(DcMotor.Direction.REVERSE); TreadLeft = hardwareMap.dcMotor.get("TreadLeft"); TreadRight = hardwareMap.dcMotor.get("TreadRight"); ArmMotor = hardwareMap.dcMotor.get("ArmMotor"); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void initGyro() {\r\n\t\tresult = new AccumulatorResult();\r\n\t\tif (m_analog1 == null || m_analog2 == null) {\r\n\t\t\tSystem.out.println(\"Null m_analog\");\r\n\t\t}\r\n\t\tm_voltsPerDegreePerSecond = kDefaultVoltsPerDegreePerSecond;\r\n\t\t\r\n\t\t\r\n\t\tm_analog1.setAverageBits(kAverageBits);\r\n\t\tm_analog1.setOversampleBits(kOversampleBits);\r\n\t\t\r\n\t\tm_analog2.setAverageBits(kAverageBits);\r\n\t\tm_analog2.setOversampleBits(kOversampleBits);\r\n\t\t\r\n\t\t\r\n\t\tdouble sampleRate = kSamplesPerSecond\r\n\t\t\t\t* (1 << (kAverageBits + kOversampleBits));\r\n\t\tAnalogInput.setGlobalSampleRate(sampleRate);\r\n\t\tTimer.delay(1.0);\r\n\r\n\t\tm_analog1.initAccumulator();\r\n\t\tm_analog1.resetAccumulator();\r\n\t\tm_analog2.initAccumulator();\r\n\t\tm_analog2.resetAccumulator();\r\n\r\n\t\tTimer.delay(kCalibrationSampleTime);\r\n\r\n\t\tfor(int i =0 ; i < mAnalogs.length; i++)\r\n\t\t{\r\n\t\t\tmAnalogs[i].getAccumulatorOutput(result);\r\n\t\r\n\t\t\tm_centers[i]= (int) ((double) result.value / (double) result.count + .5);\r\n\t\r\n\t\t\tm_offsets[i] = ((double) result.value / (double) result.count)\r\n\t\t\t\t\t- m_centers[i];\r\n\t\r\n\t\t\tmAnalogs[i].setAccumulatorCenter(m_centers[i]);\r\n\t\t\tmAnalogs[i].resetAccumulator();\r\n\t\r\n\t\t\t\r\n\t\t\t//LiveWindow.addSensor(\"Gyro\", m_analog.getChannel(), this);\r\n\t\t}\r\n\t\tif(mMode == TWO_CANCEL) setDeadband(kCancelDeadband);\r\n\t\telse if(mMode == TWO_DEADBAND) {\r\n\t\t\tsetDeadband1(0.0);\r\n\t\t\tmAccumulatedAngle = 0;\r\n\t\t}\r\n\t\t\r\n\t\tmOffset = 0;\r\n\t}", "private void CalibrateGyro() {\n BNO055IMU.Parameters parameters = new BNO055IMU.Parameters();\n parameters.mode = BNO055IMU.SensorMode.IMU;\n parameters.angleUnit = BNO055IMU.AngleUnit.DEGREES;\n imu.initialize(parameters);\n while (!imu.isGyroCalibrated()){}\n }", "@Override\n public void runOpMode() {\n androidGyroscope = new AndroidGyroscope();\n\n // Put initialization blocks here.\n if (androidGyroscope.isAvailable()) {\n telemetry.addData(\"Status\", \"GyroAvailable\");\n }\n waitForStart();\n if (opModeIsActive()) {\n // Put run blocks here.\n androidGyroscope.startListening();\n androidGyroscope.setAngleUnit(AngleUnit.DEGREES);\n while (opModeIsActive()) {\n telemetry.addData(\"X Axis\", androidGyroscope.getX());\n telemetry.update();\n }\n }\n }", "public interface Gyro {\n /**\n * Get the amount of time the gyro spends calibrating\n *\n * @return Length of gyro calibration period\n */\n double getCalibrationPeriod();\n\n /**\n * Set the amount of time the gyro will spend calibrating\n *\n * @param calibrationPeriod Desired length of gyro calibration period\n */\n void setCalibrationPeriod(double calibrationPeriod);\n\n /**\n * Reset calibration and angle monitoring\n */\n void fullReset();\n\n /**\n * Starts calibrating the gyro. Resets the calibration value and begins\n * sampling gyro values to get the average 0 value. Sample time determined\n * by calibrationTicks\n */\n void startCalibration();\n\n /**\n * Finishes calibration. Stops calibrating and sets the calibration value.\n */\n void finishCalibration();\n\n /**\n * Gets the zero point for rate measurement\n *\n * @return The offset found by calibration\n */\n double getCalibrationOffset();\n\n /**\n * Checks if the gyro is currently calibrating.\n * If it is, measured rate and angle values are not guaranteed to be accurate.\n *\n * @return Whether the gyro is currently calibrating\n */\n boolean isCalibrating();\n\n /**\n * Gets the rate of yaw change from the gyro\n *\n * @return The rate of yaw change in degrees per second, positive is clockwise\n */\n double getRate();\n\n /**\n * Gets the yaw of the gyro\n *\n * @return The yaw of the gyro in degrees\n */\n double getAngle();\n\n /**\n * Resets the current angle of the gyro to zero\n */\n void resetAngle();\n}", "public Gyro (){\n try {\n /* Communicate w/navX MXP via the MXP SPI Bus. */\n /* Alternatively: I2C.Port.kMXP, SerialPort.Port.kMXP or SerialPort.Port.kUSB */\n /* See http://navx-mxp.kauailabs.com/guidance/selecting-an-interface/ for details. */\n gyro_board = new AHRS(SPI.Port.kMXP);\n\n last_world_linear_accel_x = gyro_board.getWorldLinearAccelX();\n last_world_linear_accel_y = gyro_board.getWorldLinearAccelY();\n last_check_time = Timer.getFPGATimestamp();\n\n initial_offset = gyro_board.getYaw();\n } catch (RuntimeException ex ) {\n DriverStation.reportError(\"Error instantiating navX MXP: \" + ex.getMessage(), true);\n }\n\n\n }", "public void calibrateGyro() {\n gyro.SetYaw(0);\n }", "public void updateGyro() {\n\t\tangleToForward = gyro.getAngle();\n\t\tif (angleToForward >= 360) {\n\t\t\tangleToForward -= 360;\n\t\t} else if (angleToForward < 0) {\n\t\t\tangleToForward += 360;\n\t\t}\n\n\t}", "protected void initialize() {\n \tRobot.gyroSubsystem.reset();\n \tstartAngle = Robot.gyroSubsystem.gyroPosition();\n \ttargetAngle = startAngle + goal;\n }", "@Override\n public void run() {\n hdt.gyroTurn180Fast(1500);\n hdt.gyroTurn180(1100);\n //sleep(1300);\n }", "public void gyroTurn ( double speed, double angle, double timeoutS) {\n\n eTime.reset();\n\n // keep looping while we are still active, and not on heading.\n while (opModeIsActive() && (eTime.seconds() < timeoutS) && !onHeading(speed, angle, P_TURN_COEFF)) {\n // Update telemetry & Allow time for other processes to run.\n telemetry.update();\n }\n }", "public void gyroDriveSec(double power, double seconds) throws InterruptedException{\n //restart angle tracking\n resetAngle();\n\n //create an ElapsedTime object to track the time the robot moves\n ElapsedTime timer = new ElapsedTime();\n //restart time tracking\n timer.reset();\n\n //drive straight with gyro until timer reaches number of given seconds\n while(timer.seconds() < seconds && opMode.opModeIsActive()){\n //Get a correction\n double correction = getCorrection();\n //Use the correction to adjust robot power so robot drives straight\n tankDrive(power + correction, power - correction);\n }\n completeStop();\n //Wait .5 seconds to ensure robot is stopped before continuing\n Thread.sleep(500);\n resetAngle();\n }", "@Override public void init_loop() {\n if (gyro.isCalibrated()) {\n telemetry.addData(\"Gyro\", \"Calibrated\");\n }\n\n /** Place any code that should repeatedly run after INIT is pressed but before the op mode starts here. **/\n }", "public void gyroTurn(int degrees, double power) throws InterruptedException{\n //restart angle tracking\n resetAngle();\n\n if(degrees < 0){\n turnClockwise(power);\n }else if(degrees > 0){\n turnCounterClockwise(power);\n }else{\n return;\n }\n\n //Rotate until current angle is equal to the target angle\n if (degrees < 0){\n while (opMode.opModeIsActive() && getAngle() > degrees){\n composeAngleTelemetry();\n //display the target angle\n telemetry.addData(\"Target angle\", degrees);\n telemetry.update();\n }\n }else{\n while (opMode.opModeIsActive() && getAngle() < degrees) {\n composeAngleTelemetry();\n //display the target angle\n telemetry.addData(\"Target angle\", degrees);\n telemetry.update();\n }\n }\n\n completeStop();\n //Wait .5 seconds to ensure robot is stopped before continuing\n Thread.sleep(500);\n resetAngle();\n }", "protected void initialize() {\n \tDrivetrain.gyro.reset();\n }", "@Override\n public void onSensorChanged(SensorEvent event) {\n if (timerFlag) {\n sendInfo(\"heart\", (sim_flag ? bpm/sim_scale : bpm));\n timerFlag = false;\n\n HR_i++;\n if(HR_i>9) {\n HR_i = 0;\n over = true;\n }\n\n if (over)\n {\n HeartRateAvg = 0;\n for (int i=0;i<10;i++)\n {\n HeartRateAvg = HeartRateAvg + HeartRate[i];\n }\n HeartRateAvg = HeartRateAvg/10;\n if ((bpm>HeartRateAvg*1.3 || bpm<HeartRateAvg*0.7) && !sendAttackFlag && sendAttackFlagCnt>15)\n {\n sendInfo(\"attack\",0);\n sendAttackFlag = true;\n Toast.makeText(getApplicationContext(), \"HeartAttack\", Toast.LENGTH_SHORT).show();\n }\n sendAttackFlagCnt++;\n if (sendAttackFlag) {\n sendAttackFlagCnt++;\n if (sendAttackFlagCnt>10)\n {\n sendAttackFlagCnt=0;\n sendAttackFlag = false;\n }\n }\n }\n HeartRate[HR_i] = bpm;\n sendInfo (\"avg\", HeartRateAvg);\n }\n\n // Update the accelerometer\n if (flag) {\n if (event.sensor.getType() == Sensor.TYPE_ACCELEROMETER) {\n final float alpha = (float) 0.8;\n // Isolate the force of gravity with the low-pass filter.\n gravity[0] = alpha * gravity[0] + (1 - alpha) * event.values[0];\n gravity[1] = alpha * gravity[1] + (1 - alpha) * event.values[1];\n gravity[2] = alpha * gravity[2] + (1 - alpha) * event.values[2];\n\n // Remove the gravity contribution with the high-pass filter.\n linear_acceleration[0] = event.values[0] - gravity[0];\n linear_acceleration[1] = event.values[1] - gravity[1];\n linear_acceleration[2] = event.values[2] - gravity[2];\n\n totAcc = Math.sqrt(linear_acceleration[0] * linear_acceleration[0] +\n linear_acceleration[1] * linear_acceleration[1] +\n linear_acceleration[2] * linear_acceleration[2]);\n\n fallAcc = linear_acceleration[2];\n }\n\n // Update the heart rate\n if (event.sensor.getType() == Sensor.TYPE_HEART_RATE) {\n bpm = event.values[0];\n if (sim_flag)\n bpm = bpm/sim_scale;\n\n String message = String.valueOf ((int) bpm) + \" bpm\";\n heart.setText(message);\n }\n\n flag = false;\n\n FallCounter = ((totAcc > threshold) ? FallCounter + 1 : 0);\n\n if (FallCounter == 5 && !detected) {\n fallDetectionAction();\n }\n }\n }", "public Gyro2903(GYRO_TYPE gyroType) {\n\t\tgyroToUse = gyroType;\n\n\t\tswitch (gyroType) {\n\t\tcase ANALOG:\n\t\t\tgyro = new AnalogGyro(RobotMap.AnalogGyro);\n\t\t\tbreak;\n\n\t\tcase SPI:\n\t\t\tspi = new ADXRS450_Gyro(SPI.Port.kOnboardCS0);\n\t\t\tbreak;\n\n\t\tcase IMU:\n\t\t\timu = new ADIS16448_IMU();\n\t\t\tbreak;\n\t\t}\n\t}", "void gyroSafety(){\n }", "@Override //when init is pressed\n public void runOpMode(){\n robot.initMotors(hardwareMap);\n robot.initServos(hardwareMap);\n robot.useEncoders(false);\n\n waitForStart();\n runtime.reset();\n\n double speedSet = 5;//robot starts with speed 5 due to 40 ratio motors being op\n double reduction = 7.5;//fine rotation for precise stacking. higher value = slower rotation using triggers\n double maxPower = 0;\n\n boolean forks = false;\n\n while (opModeIsActive()) {\n double LX = gamepad1.left_stick_x, LY = gamepad1.left_stick_y, rotate = gamepad1.right_stick_x;\n\n //bumpers set speed of robot\n if(gamepad1.right_bumper)\n speedSet += 0.0005;\n else if(gamepad1.left_bumper)\n speedSet -= 0.0005;\n\n speedSet = Range.clip(speedSet, 1, 10);//makes sure speed is limited at 10.\n\n if(!gamepad1.right_bumper && !gamepad1.left_bumper)//makes sure speed does not round every refresh. otherwise, speed won't be able to change\n speedSet = Math.round(speedSet);\n\n if(gamepad1.a) {\n forks = !forks;\n sleep(50);\n }\n\n if(forks) {\n robot.setForks(DOWN);\n }\n else if(earthIsFlat) {\n robot.setForks(UP);\n }\n\n //Holonomic Vector Math\n robot.drive(LX, LY, rotate);\n\n telemetry.addData(\"Drive\", \"Holonomic\");\n\n if(forks)\n telemetry.addData(\"Forks\", \"DOWN\");\n else\n telemetry.addData(\"Forks\", \"UP\");\n\n telemetry.addData(\"speedSet\", \"%.2f\", speedSet);\n telemetry.update();\n }\n }", "@Override\n public void teleopPeriodic() {\n double pi4 = (double)Math.PI/4;\n/*\n double deadzoneX = 0.1;\n double multiplierX = 1/deadzoneX;\n double deadzoneY = 0.1;\n double multiplierY = 1/deadzoneY;\n\n double maxSpeed = stick.getThrottle() * 1f;\nstick.getX()/Math.abs(stick.getX())\n double stickX;\n if (Math.abs(stick.getX())< deadzoneX){\n stickX = 0;\n }\n\n else {\n stickX = ((stick.getMagnitude() * Math.sin(stick.getDirectionRadians())) - deadzoneX)*multiplierX;\n }\n\n \n double stickY;\n if (Math.abs(stick.getY())< deadzoneY){\n stickY = 0;\n }\n\n else {\n stickY = (stick.getMagnitude() * Math.cos(stick.getDirectionRadians()) - deadzoneY)*multiplierY;\n }\n \n\n double stickTwist = stick.getTwist();\n\n double leftFrontForwardsPower = -stickY;\n double rightFrontForwardsPower = stickY;\n double leftBackForwardsPower = -stickY;\n double rightBackForwardsPower = stickY;\n\n double leftFrontSidePower = -stickX;\n double rightFrontSidePower = -stickX;\n double leftBackSidePower = +stickX;\n double rightBackSidePower = stickX;\n\n double leftFrontRotatePower = -stickTwist;\n double rightFrontRotatePower = -stickTwist;\n double leftBackRotatePower = -stickTwist;\n double rightBackRotatePower = -stickTwist;\n\n */\n\n /* get gyro from robot\n set gyro tto original gyro\n void()\n\n get X for joystick\n get Y for Joystick\n\n get gyro for robot\n\n if X = 0\n then Joystick angle pi/2\n else\n then Joystick angle = arctan(Y/X)\n\n newGyro = original gyro - gyro\n\n xfinal = cos(newGyro+joystickangle) * absolute(sqrt(x^2+y^2))\n yfinal = sin(newGyro+joystickangle) * absolute(sqrt(x^2+y^2))\n*/\n\n//Xbox COntroller\n \n double maxSpeed = stick.getThrottle() * 0.2f;\n double maxRot = 1f;\n\n double controllerX = -controller.getX(Hand.kRight);\n double controllerY = controller.getY(Hand.kRight);\n double joyAngle;\n boolean gyroRestart = controller.getAButtonPressed();\n\n if (gyroRestart){\n gyro.reset();\n origGyro = Math.toRadians(gyro.getAngle());\n }\n\n double mainGyro = Math.toRadians(gyro.getAngle());\n/*\n if (controllerX == 0 && controllerY > 0){\n joyAngle = (3*Math.PI)/2;\n }\n\n \n if (controllerX == 0 && controllerY < 0){\n joyAngle = Math.PI/2;\n }\n\n else{\n joyAngle = Math.atan(controllerY/controllerX);\n }\n\n if (controllerX > 0 && controllerY < 0){\n joyAngle = Math.abs(joyAngle + Math.toRadians(180));\n }\n if (controllerX > 0 && controllerY > 0){\n joyAngle -= Math.toRadians(180);\n }\n / * if (controllerX < 0 && controllerY > 0){\n joyAngle -= Math.toRadians(270);\n }* /\n*/\n joyAngle = Math.atan2(controllerY, controllerX);\n\n double newGyro = origGyro - mainGyro;\n //double newGyro = 0;\n\n double controllerTurn = -controller.getX(Hand.kLeft)*maxRot;\n\n double magnitude = Math.abs(Math.sqrt(Math.pow(controllerX,2) + Math.pow(controllerY, 2)));\n\n double xFinal = Math.cos(newGyro + joyAngle) * magnitude;\n double yFinal = Math.sin(newGyro + joyAngle) * magnitude;\n\n\n /* \n double leftFrontForwardsPower = -controllerY;\n double rightFrontForwardsPower = controllerY;\n double leftBackForwardsPower = -controllerY;\n double rightBackForwardsPower = controllerY;\n\n double leftFrontSidePower = -controllerX;\n double rightFrontSidePower = -controllerX;\n double leftBackSidePower = controllerX;\n double rightBackSidePower = controllerX;\n*/\n \n double leftFrontForwardsPower = -yFinal;\n double rightFrontForwardsPower = yFinal;\n double leftBackForwardsPower = -yFinal;\n double rightBackForwardsPower = yFinal;\n\n double leftFrontSidePower = -xFinal;\n double rightFrontSidePower = -xFinal;\n double leftBackSidePower = xFinal;\n double rightBackSidePower = xFinal;\n \n double leftFrontRotatePower = -controllerTurn;\n double rightFrontRotatePower = -controllerTurn;\n double leftBackRotatePower = -controllerTurn;\n double rightBackRotatePower = -controllerTurn;\n\n double forwardsWeight = 1;\n double sideWeight = 1;\n double rotateWeight = 1;\n\n double leftFrontPower = leftFrontForwardsPower * forwardsWeight + leftFrontSidePower * sideWeight + leftFrontRotatePower * rotateWeight;\n double rightFrontPower = rightFrontForwardsPower * forwardsWeight + rightFrontSidePower * sideWeight + rightFrontRotatePower * rotateWeight;\n double leftBackPower = leftBackForwardsPower * forwardsWeight + leftBackSidePower * sideWeight + leftBackRotatePower * rotateWeight;\n double rightBackPower = rightBackForwardsPower * forwardsWeight + rightBackSidePower * sideWeight + rightBackRotatePower * rotateWeight;\n\n leftFrontPower *= maxSpeed;\n rightFrontPower *= maxSpeed;\n leftBackPower *= maxSpeed;\n rightBackPower *= maxSpeed;\n\n\n double largest = Math.max( \n Math.max( Math.abs( leftFrontPower),\n Math.abs(rightFrontPower)),\n Math.max( Math.abs( leftBackPower), \n Math.abs( rightBackPower)));\n\n if (largest > 1) {\n leftFrontPower /= largest;\n rightFrontPower /= largest;\n leftBackPower /= largest;\n rightBackPower /= largest;\n }\n \n \n leftFrontMotor.set(leftFrontPower);\n rightFrontMotor.set(rightFrontPower); \n leftBackMotor.set(leftBackPower);\n rightBackMotor.set(rightBackPower);\n\n SmartDashboard.putNumber(\"Main Gyro\", mainGyro);\n SmartDashboard.putNumber(\"Original Gyro\", origGyro);\n SmartDashboard.putNumber(\"New Gyro\", newGyro);\n SmartDashboard.putNumber(\"Controller X\", controllerX);\n SmartDashboard.putNumber(\"Controller Y\", controllerY);\n SmartDashboard.putNumber(\"Magnitude \", magnitude);\n SmartDashboard.putNumber(\"Largest\", largest);\n SmartDashboard.putNumber(\"Joystick Angle\", Math.toDegrees(joyAngle));\n SmartDashboard.putNumber(\"X final\", xFinal);\n SmartDashboard.putNumber(\"Y final\", yFinal);\n SmartDashboard.putNumber(\"Left Front Power\", leftFrontPower);\n SmartDashboard.putNumber(\"Right Front Power\", rightFrontPower);\n SmartDashboard.putNumber(\"Left Back Power\", leftBackPower);\n SmartDashboard.putNumber(\"Right Back Power\", rightBackPower);\n }", "@Override\n public void teleopPeriodic() {\n double x = xcontroller2.getX(Hand.kLeft);\n //double y = xcontroller1.getTriggerAxis(Hand.kRight) - xcontroller1.getTriggerAxis(Hand.kLeft);\n // For testing just use left joystick. Use trigger axis code for GTA Drive/\n double y = -xcontroller2.getY(Hand.kLeft);\n double z = xcontroller2.getX(Hand.kRight);\n double yaw = imu.getAngleZ();\n RobotDT.driveCartesian(x, y, 0, 0);\n \n\n // After you spin joystick R3 press A button to reset gyro angle\n if (xcontroller1.getAButtonPressed()) {\n imu.reset();\n }\n \n if (xcontroller2.getBButtonPressed()){\n mGPM.goSpongeHatch();\n }\n\n if (xcontroller2.getXButtonPressed()){\n mGPM.goPineHome();\n \n }\n\n\n /** \n * If Bumpers are pressed then Cargo Intake Motor = -1 for Intake \n *if Triggers are pressed set value to 1 for Outtake\n *If triggers are released set value to 0*/\n if(xcontroller2.getBumperPressed(Hand.kLeft) && xcontroller2.getBumperPressed(Hand.kRight)) {\n mGPM.setCargoMotor(-1);\n } else if((xcontroller2.getTriggerAxis(Hand.kLeft) >0.75) && (xcontroller2.getTriggerAxis(Hand.kRight) >0.75)) {\n mGPM.setCargoMotor(1);\n } else{\n mGPM.setCargoMotor(0);\n }\n }", "public static Gyro getGyro() {\n return sGyro;\n }", "public void gyroStrafeSec(double power, double angle, double seconds) throws InterruptedException{\n //restart angle tracking\n resetAngle();\n\n //convert direction (degrees) into radians\n double newDirection = angle * Math.PI/180 + Math.PI/4;\n //calculate powers needed using direction\n double leftPower = Math.cos(newDirection) * power;\n double rightPower = Math.sin(newDirection) * power;\n\n //create an ElapsedTime object to track the time the robot moves\n ElapsedTime timer = new ElapsedTime();\n //restart time tracking\n timer.reset();\n\n //strafe using gyro to keep robot facing straight for\n while(timer.seconds() < seconds && opMode.opModeIsActive()){\n //Get a correction\n double correction = getCorrection();\n //Use the correction to adjust robot power so robot faces straight\n correctedTankStrafe(leftPower, rightPower, correction);\n }\n completeStop();\n //Wait .5 seconds to ensure robot is stopped before continuing\n Thread.sleep(500);\n resetAngle();\n }", "public final void GyroStrafeDistance (int Distance, double power)\n {\n //Define variable for the right range senson that measures centimeters\n double RightRangeDistance = RightRange.getDistance(DistanceUnit.CM);\n\n //While the robot's distance is less than the wanted distance do the following\n while (Distance >= RightRangeDistance && opModeIsActive())\n {\n //Define variable for gyro angle\n float GyroAngle = robot.Gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle;\n\n //Update the variable for the range sensor\n RightRangeDistance = RightRange.getDistance(DistanceUnit.CM);\n\n //If the gyro's read angle is more than 3 degrees turn right until it is not\n if (GyroAngle > 3 )\n {\n while(GyroAngle > 3 && opModeIsActive())\n {\n //Turn Right\n robot.DriveLeftBack.setPower(-.1);\n robot.DriveRightBack.setPower(.1);\n robot.DriveRightFront.setPower(.1);\n robot.DriveLeftFront.setPower(-.1);\n\n //Update the gyro's angle\n GyroAngle = robot.Gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle;\n }\n }\n\n //If the gyro's read angle is less than -3 degrees turn left until it is not\n else if (GyroAngle < -3)\n {\n while (GyroAngle < -3 && opModeIsActive())\n {\n //Turn Left\n robot.DriveLeftBack.setPower(.1);\n robot.DriveRightBack.setPower(-.1);\n robot.DriveRightFront.setPower(-.1);\n robot.DriveLeftFront.setPower(.1);\n\n //Update the gyro's angle\n GyroAngle = robot.Gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle;\n }\n }\n\n //Strafe (right or left)\n robot.DriveLeftBack.setPower(-power);\n robot.DriveRightBack.setPower(power);\n robot.DriveRightFront.setPower(-power);\n robot.DriveLeftFront.setPower(power);\n\n //Send feedback to phone\n telemetry.addData(\"Angle\",\n GyroAngle);\n telemetry.addData(\"Distance\", RightRangeDistance);\n telemetry.update();\n\n //End of loop, robot will repeat the above until it reaches the wanted distance\n }\n robot.DriveLeftBack.setPower(0);\n robot.DriveRightBack.setPower(0);\n robot.DriveRightFront.setPower(0);\n robot.DriveLeftFront.setPower(0);\n }", "@Override\n public void runOpMode() throws InterruptedException{\n\n LeftWheel = hardwareMap.dcMotor.get(\"LeftWheel\");\n RightWheel = hardwareMap.dcMotor.get(\"RightWheel\");\n LLAMA = hardwareMap.dcMotor.get(\"LLAMA\");\n RightWheel.setDirection(DcMotor.Direction.REVERSE);\n beaconFlagSensor = hardwareMap.i2cDevice.get(\"color sensor\");\n LeftWheel.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n RightWheel.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n buttonPusher = hardwareMap.servo.get(\"Button Pusher\");\n buttonPusher.setDirection(Servo.Direction.REVERSE);\n\n LeftWheel.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n RightWheel.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n LLAMA.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n\n beaconFlagReader= new I2cDeviceSynchImpl(beaconFlagSensor, I2cAddr.create8bit(0x3c), false);\n beaconFlagReader.engage();\n\n double PUSHER_MIN = 0;\n double PUSHER_MAX = 1;\n buttonPusher.scaleRange(PUSHER_MIN,PUSHER_MAX);\n\n if(beaconFlagLEDState){\n beaconFlagReader.write8(3, 0); //Set the mode of the color sensor using LEDState\n }\n else{\n beaconFlagReader.write8(3, 1); //Set the mode of the color sensor using LEDState\n }\n\n\n waitForStart();\n //Go forward to position to shoot\n long iniForward = 0;\n //Shoot LLAMA\n long shootLLAMA=0 ;\n //Turn towards Wall\n long turnToWall= 0;\n //Approach Wall\n long wallApproach= 0;\n //Correct to prepare for button\n long correctForButton= 0;\n long correctForButton2=0 ;\n //Use sensors to press button\n /** This is sensor*/\n //Go forward\n long toSecondButton= 0;\n //Use Sensors to press button\n /** This is sensor*/\n //turn to center\n\n //charge\n long chargeTime= 0;\n\n //Go forward to position to shoot\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(iniForward);\n\n STOP();\n\n //Shoot LLAMA\n LLAMA.setPower(1);\n\n sleep(shootLLAMA);\nSTOP();\n //Turn towards Wall\n LeftWheel.setPower(-1);\n RightWheel.setPower(1);\n\n sleep(turnToWall);\n\n STOP();\n //Approach Wall\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(wallApproach);\n\n STOP();\n //Correct to prepare for button\n\n LeftWheel.setPower(1);\n RightWheel.setPower(-1);\n\n sleep(correctForButton);\n\n STOP();\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(correctForButton2);\n\n STOP();\n topCache = beaconFlagReader.read(0x04, 1);\n //Use sensors to press button\n if ((topCache[0] & 0xFF) <=4 && (topCache[0] & 0xFF) > 0 &&(topCache[0] & 0xFF) <16) {\n while (((topCache[0] & 0xFF) <=4 && (topCache[0] & 0xFF) > 0 &&\n (topCache[0] & 0xFF) <16) && opModeIsActive()) {\n\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n sleep(100);\n LeftWheel.setPower(0);\n RightWheel.setPower(0);\n topCache = beaconFlagReader.read(0x04, 1);\n\n if ((topCache[0] & 0xFF) >=7 && (topCache[0] & 0xFF) >= 0){\n telemetry.addLine(\"Color Detected, Pressing Button...\");\n telemetry.update();\n buttonPusher.setPosition(PUSHER_MAX);\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(100);\n\n STOP();\n break;\n }\n }\n\n }\n\n else if ((topCache[0] & 0xFF) >=7 && (topCache[0] & 0xFF) >= 0) {\n telemetry.addLine(\"Color Detected, Pressing Button...\");\n telemetry.update();\n buttonPusher.setPosition(PUSHER_MAX);\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(100);\n\n STOP();\n }\n\n //Go forward\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(toSecondButton);\n\n STOP();\n //Use Sensors to press button\n topCache = beaconFlagReader.read(0x04, 1);\n //Use sensors to press button\n if ((topCache[0] & 0xFF) <=4 && (topCache[0] & 0xFF) > 0 &&(topCache[0] & 0xFF) <16) {\n while (((topCache[0] & 0xFF) <=4 && (topCache[0] & 0xFF) > 0 &&\n (topCache[0] & 0xFF) <16) && opModeIsActive()) {\n\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n sleep(100);\n LeftWheel.setPower(0);\n RightWheel.setPower(0);\n topCache = beaconFlagReader.read(0x04, 1);\n\n if ((topCache[0] & 0xFF) >=7 && (topCache[0] & 0xFF) >= 0){\n telemetry.addLine(\"Color Detected, Pressing Button...\");\n telemetry.update();\n buttonPusher.setPosition(PUSHER_MAX);\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(100);\n\n STOP();\n break;\n }\n }\n\n }\n\n else if ((topCache[0] & 0xFF) >=7 && (topCache[0] & 0xFF) >= 0) {\n telemetry.addLine(\"Color Detected, Pressing Button...\");\n telemetry.update();\n buttonPusher.setPosition(PUSHER_MAX);\n\n LeftWheel.setPower(1);\n RightWheel.setPower(1);\n\n sleep(100);\n\n STOP();\n }\n\n //turn to center\n\n\n //charge\n }", "public double[] getGyro();", "public void gyroTurn ( double speed, double angle) {\n\n // keep looping while we are still active, and not on heading.\n while (!onHeading(speed, angle, P_TURN_COEFF) ) {\n // Update telemetry & Allow time for other processes to run.\n try {\n sleep(50);\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n }\n\n }", "@Override\n public void runOpMode() throws InterruptedException {\n robot = new OptimizedRobot(gamepad1, gamepad2, telemetry, hardwareMap);\n\n // Grab our controller 1 using robot.getController1()\n\n controller1 = robot.getController1();\n\n // Grab our our encoders using robot.getEncoder() there are TWO of them\n // Use xEncoder and yEncoder for the names!\n\n xEncoder = robot.getEncoder(\"XEncoder\");\n yEncoder = robot.getEncoder(\"YEncoder\");\n\n // Reverse the direction of our left encoder using encoder.setDirection()\n\n xEncoder.setDirection(Encoder.Direction.REVERSE);\n\n\n // Waiting for the play button to be pressed\n waitForStart();\n\n robot.log(\"Instructions\", \"Your job is the move the robot \"+DISTANCE_TO_TRAVEL+\" forward and right for each trial!\");\n\n for(int i = 0; i < NUM_SAMPLES; i++) {\n robot.addLog(\"Prompt\", \"Trial #\"+(i+1)+\" of \"+NUM_SAMPLES);\n robot.addLog(\"Prompt\", \"Set up your robot on its start position and press A to start the tuning!\");\n robot.pushLog();\n\n while(!controller1.getBool(OptimizedController.Key.A)) {\n }\n\n prevX = xEncoder.getCurrentPosition();\n prevY = yEncoder.getCurrentPosition();\n\n robot.addLog(\"Running\", \"Drag your robot forward \"+DISTANCE_TO_TRAVEL+\" inches and \"+DISTANCE_TO_TRAVEL+\" inches to the right!\");\n robot.addLog(\"Running\", \"Try to keep the robot straight the entire time--try using a line on the floor for reference.\");\n robot.addLog(\"Instructions\", \"Press B when you have finished moving the robot!\");\n robot.pushLog();\n\n while(!controller1.getBool(OptimizedController.Key.B)) {\n estimatedX = xEncoder.getCurrentPosition() - prevX;\n estimatedY = yEncoder.getCurrentPosition() - prevY;\n }\n\n xTraveled[i] = estimatedX;\n yTraveled[i] = estimatedY;\n }\n\n\n double xCoefficient = 0;\n double yCoefficient = 0;\n\n for(int num : xTraveled) {\n xCoefficient += (TICKS_PER_REV * (DISTANCE_TO_TRAVEL / (2 * Math.PI * ODOMETRY_WHEEL_RADIUS))) / num;\n }\n\n for(int num : yTraveled) {\n yCoefficient += (TICKS_PER_REV * (DISTANCE_TO_TRAVEL / (2 * Math.PI * ODOMETRY_WHEEL_RADIUS))) / num;\n }\n\n xCoefficient /= NUM_SAMPLES;\n yCoefficient /= NUM_SAMPLES;\n\n robot.addLog(\"xEncoder Coefficient = \", Math.abs(xCoefficient));\n robot.addLog(\"yEncoder Coefficient = \", Math.abs(yCoefficient));\n robot.pushLog();\n\n while(opModeIsActive()) {\n }\n }", "public void resetGyro(){\n //TODO:Reset the gyro(zero it)\n }", "public void onSensorChanged(SensorEvent event) {\n if (event.sensor.getType() != Sensor.TYPE_ACCELEROMETER && event.sensor.getType() != Sensor.TYPE_GYROSCOPE)\n return;\n\n if(event.sensor.getType() == Sensor.TYPE_ACCELEROMETER) {\n sensorCount++;\n\n if (sensorFirstRead) {\n nanotime = System.nanoTime();\n sensorFirstRead = false;\n } else {\n\n if (sensorCount > 0 && sensorCount % 10 == 0) {\n differenceNanoTime = System.nanoTime() - nanotime;\n if (differenceNanoTime > sensorCounterIntervalDelay) {\n differenceSeconds = (double) differenceNanoTime / 1000000000f;\n\n sensorAverageCount = sensorCount / differenceSeconds;\n sensorAverageCountTextView.setText(String.format(\"Read/s: %.2f\", sensorAverageCount));\n\n if (sensorFirstAverageCycle || Math.abs(sensorAverageCount - accValuesLimit * 2) > accValuesLimit * 0.2) {\n if (sensorFirstAverageCycle)\n sensorFirstAverageCycle = false;\n\n accValuesLimit = (int) sensorAverageCount / 2;\n gyroValuesLimit = accValuesLimit / 2;\n sensorCountLimitTextView.setText(String.format(\"Sensor count limit: %d\", accValuesLimit));\n\n stats.get(\"accX\").setLimit(accValuesLimit);\n stats.get(\"accY\").setLimit(accValuesLimit);\n stats.get(\"accZ\").setLimit(accValuesLimit);\n stats.get(\"accDegreeZ\").setLimit(accValuesLimit);\n stats.get(\"accDegreeX\").setLimit(accValuesLimit);\n stats.get(\"accDegreeY\").setLimit(accValuesLimit);\n stats.get(\"accTotalAcceleration\").setLimit(accValuesLimit);\n stats.put(\"gyroX\", new StatisticList(gyroValuesLimit));\n stats.put(\"gyroY\", new StatisticList(gyroValuesLimit));\n stats.put(\"gyroZ\", new StatisticList(gyroValuesLimit));\n }\n\n sensorCount = 0;\n nanotime = System.nanoTime();\n }\n }\n }\n }\n\n if(event.sensor.getType() == Sensor.TYPE_ACCELEROMETER) {\n\n mAccelerometerSensorX = event.values[0];\n mAccelerometerSensorY = event.values[1];\n mAccelerometerSensorZ = event.values[2];\n\n mAccelerometerTotalAcceleration = Math.sqrt(Math.pow(mAccelerometerSensorX, 2) + Math.pow(mAccelerometerSensorY, 2) + Math.pow(mAccelerometerSensorZ, 2));\n\n stats.get(\"accX\").addValue(mAccelerometerSensorX);\n stats.get(\"accY\").addValue(mAccelerometerSensorY);\n stats.get(\"accZ\").addValue(mAccelerometerSensorZ);\n stats.get(\"accTotalAcceleration\").addValue(mAccelerometerTotalAcceleration);\n\n tmp_y = stats.get(\"accY\").getAverage() / stats.get(\"accTotalAcceleration\").getAverage(); // g\n tmp_x = stats.get(\"accX\").getAverage() / stats.get(\"accTotalAcceleration\").getAverage();\n tmp_z = stats.get(\"accZ\").getAverage() / stats.get(\"accTotalAcceleration\").getAverage();\n\n mRotationDegreeZ = Math.asin(tmp_x) * 180 / Math.PI;\n if (Double.isNaN(mRotationDegreeZ))\n mRotationDegreeZ = stats.get(\"accDegreeZ\").getAverage() > 0 ? 90 : -90;\n\n mRotationDegreeX = Math.asin(tmp_z) * 180 / Math.PI;\n if (Double.isNaN(mRotationDegreeX))\n mRotationDegreeX = stats.get(\"accDegreeX\").getAverage() > 0 ? 90 : -90;\n\n mRotationDegreeY = Math.asin(tmp_y) * 180 / Math.PI;\n if (Double.isNaN(mRotationDegreeY))\n mRotationDegreeY = stats.get(\"accDegreeY\").getAverage() > 0 ? 90 : -90;\n\n stats.get(\"accDegreeZ\").addValue(mRotationDegreeZ);\n stats.get(\"accDegreeX\").addValue(mRotationDegreeX);\n stats.get(\"accDegreeY\").addValue(mRotationDegreeY);\n\n updateLog(Sensor.TYPE_ACCELEROMETER);\n }\n else\n if(event.sensor.getType()==Sensor.TYPE_GYROSCOPE)\n {\n mGyroX = event.values[0];\n mGyroY = event.values[1];\n mGyroZ = event.values[2];\n\n stats.get(\"gyroX\").addValue(mGyroX);\n stats.get(\"gyroY\").addValue(mGyroY);\n stats.get(\"gyroZ\").addValue(mGyroZ);\n\n updateLog(Sensor.TYPE_GYROSCOPE);\n }\n }", "@Override\n public void runOpMode() {\n\n robot.init(hardwareMap);\n robot.MotorRightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.MotorLeftFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.MotorRightFront.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n robot.MotorLeftFront.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n /** Wait for the game to begin */\n while (!isStarted()) {\n telemetry.addData(\"angle\", \"0\");\n telemetry.update();\n }\n\n\n }", "@Override\n public void gyroYaw(int value, int timestamp) {\n }", "public double getGyroInRad(){\n return 0.0;//TODO:Pull and return gyro in radians\n }", "@Override\n\tpublic void robotInit() {\n\t\toi = new OI();\n\t\tdrivebase.calibrateGyro();\n\t\tSmartDashboard.putData(\"Zero Gyro\", new ZeroGyro());\n\t\tSmartDashboard.putData(\"Calibrate Gyro - WHILE ROBOT NOT MOVING\", new CalibrateGyro());\n\t\tchooser.addDefault(\"Default Prepare Gear Auto\", new PrepareGearManipulator());\n\t\t//shooterModeChooser.addDefault(\"Shooter at Nominal Preset when Pressed\", object);\n\t\t/*chooser.addObject(\"Left Gear Auto\", new LeftGearGroup());\n\t\tchooser.addObject(\"Center Gear Auto\", new CenterGearGroup());*/\n\t//\tchooser.addObject(\"Test Vision Auto\", new TurnTillPerpVision(true));\n\t//\tchooser.addObject(\"Testing turn gyro\", new RotateToGyroAngle(90,4));\n\t\t//chooser.addObject(\"DriveStraightTest\", new GoAndReturn());\n\t\t //UNNECESSARY AUTOS FOR TESTING ^\n\t\tchooser.addObject(\"Center Gear Encoder Auto (place)\", new DriveStraightCenter());\n\t\tchooser.addObject(\"Vision center TESTING!!!\", new TurnTillPerpVision());\n\t\tchooser.addObject(\"Boiler Auto RED\", new BoilerAuto(true));\n\t\tchooser.addObject(\"Boiler Auto BLUE\", new BoilerAuto(false));\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\n\t//\tchooser.addObject(\"Center Gear Encoder Auto (do not place )\", new DriveToFace(false, false, false));\n\t\tchooser.addObject(\"Baseline\", new DriveToLeftRightFace(false,false,false,false));\n\t\tchooser.addObject(\"TEST DRIVETANK AUTO\", new DriveTimedTank(0.7,0.7,5));\n\t\tchooser.addObject(\"Side Gear Auto RIGHT (manual straight lineup)(place)(TURN AFTER AND START CYCLE)\", new DriveStraightSide(true,false));\n\n\t\tchooser.addObject(\"Side Gear Auto LEFT (manual straight lineup)(place)(TURN AFTER AND START CYCLE)\", new DriveStraightSide(true,true));\n\t\t//chooser.addObject(\"Side Gear Auto (place)\", new DriveToLeftRightFace(true,false,false,false));\n\t\t//chooser.addObject(\"Test DriveStraight Auto\", new DriveStraightPosition(10,5));\n\t\t//chooser.addObject(\"Center Gear Encoder Auto (place)\", new DriveStraightCenter());\n\t\t/*InterpreterGroup interp = new InterpreterGroup();\n\t\t(interp.init()){\n\t\t\tchooser.addObject(\"Interpreter\",interp);\n\t\t}*/\n\t\t// chooser.addObject(\"My Auto\", new MyAutoCommand());\n\t\tSmartDashboard.putData(\"Auto Chooser\", chooser);\n\n\t\tRobot.drivebase.leftDrive1.setPosition(0);\n \tRobot.drivebase.rightDrive1.setPosition(0);\n \t\n\t\t\n \tRobot.leds.initializei2cBus();\n \tbyte mode = 0;\n \tRobot.leds.setMode(mode);\n \tgearcamera = CameraServer.getInstance();\n\t\t\n \tUsbCamera gearUsb = gearcamera.startAutomaticCapture();\n \tgearUsb.setFPS(25);\n \tgearUsb.setResolution(256, 144);\n\n\t\t//NetworkTable.setClientMode();\n \t//NetworkTable.setIPAddress(\"raspberrypi.local\");\n\t\t\n\t\t\n\t\t/*\n\t\t * new Thread(() -> { UsbCamera goalcamera =\n\t\t * CameraServer.getInstance().startAutomaticCapture();\n\t\t * goalcamera.setResolution(320, 240); goalcamera.setFPS(30);\n\t\t * goalcamera.setBrightness(1); goalcamera.setExposureManual(1);\n\t\t * \n\t\t * CvSink goalCvSink = CameraServer.getInstance().getVideo();\n\t\t * \n\t\t * Mat source = new Mat();\n\t\t * \n\t\t * while(!Thread.interrupted()) { goalCvSink.grabFrame(source);\n\t\t * goaloutputmat = source; } }).start();\n\t\t * goalPipeline.process(goaloutputmat);\n\t\t * \n\t\t * new Thread(() -> { UsbCamera gearcamera =\n\t\t * CameraServer.getInstance().startAutomaticCapture();\n\t\t * gearcamera.setResolution(320, 240); gearcamera.setFPS(30);\n\t\t * gearcamera.setBrightness(1); gearcamera.setExposureManual(1);\n\t\t * \n\t\t * CvSink gearCvSink = CameraServer.getInstance().getVideo();\n\t\t * \n\t\t * Mat source = new Mat();\n\t\t * \n\t\t * while(!Thread.interrupted()) { gearCvSink.grabFrame(source);\n\t\t * gearoutputmat = source; } }).start();\n\t\t * gearPipeline.process(gearoutputmat);\n\t\t */\n\t}", "private void remapGyroVector(){\n\t\tif (referenceGyroMatrix == null){\n\t\t\ttempGyroMatrix = new float[16];\n\t\t\treferenceGyroMatrix = new float[16];\n\t\t\tMatrix.setIdentityM(tempGyroMatrix, 0);\n\t\t\tSensorManager.remapCoordinateSystem(tempGyroMatrix, remapX, remapY, referenceGyroMatrix);\n\t\t\tSystem.arraycopy(referenceGyroMatrix, 0, tempGyroMatrix, 0, 16);\n\t\t\tthis.remappedGyro = new float[4];\n\t\t\tthis.tempGyroValues = new float[4];\n\t\t\t//need to transpose, since sensor manager and matrix use different notations\n\t\t\t//Matrix.transposeM(referenceGyroMatrix, 0, tempGyroMatrix, 0);\n\t\t}\n\t\t\n\t\tfloat[] gyroValues = getValues(VALUE_KEYS.GYRO.name());\n\t\t//System.arraycopy(gyroValues, 0, this.gyroValues, 0, 3);\n\t\tSystem.arraycopy(gyroValues, 0, this.tempGyroValues, 0, 3);\n\t\tMatrix.multiplyMV(this.remappedGyro, 0, referenceGyroMatrix, 0, this.tempGyroValues, 0);\n\t\tSystem.arraycopy(this.remappedGyro, 0, this.finalGyroValues, 0, 3);\n\t\t\n\t}", "public void operatorControl() {\n \tdouble ctrlThresh = .2; \n \tdouble minPower = .05; \n \tdouble maxPower = .75; \n \tdouble recip = (1 - ctrlThresh); \n \tdouble mult = (maxPower - minPower); \n \tdouble right; \n \tdouble strafe; \n \tdouble rotate; \n \tdouble rightAxis; \n \tdouble strafeAxis; \n \tdouble rotateAxis; \n \t// \tboolean leftLeft; \n \t// \tboolean leftRight; \n \tdouble rightDir; \n \tdouble strafeDir; \n \tdouble rotateDir; \n \tdouble rightPower; \n \tdouble rotatePower; \n \tdouble strafePower; \n \t\n \tint winchCount;\n \tboolean winchDirection;\n \n \t// \tdouble frontLeftPower; \n \t// \tdouble frontRightPower; \n \t// \tdouble backLeftPower; \n \t// \tdouble backRightPower; \n \n \t//myRobot.setSafetyEnabled(true); \n \t\n \tAccelerometer test = new BuiltInAccelerometer();\n \t\n \twhile (isOperatorControl() && isEnabled()) { \n \t\t// ACCEL TEST CODE\n// \t\tSystem.out.println(test.getX() + \", \" + test.getY() + \", \" + test.getZ());\n \t\t// END ACCEL TEST CODE\n \n \t\t// ********** BEGIN DRIVING CODE ********** \n \t\t// Code for driving using omniwheels and two wheels for strafing \n \t\t// Diagram for the wheels of the robot below. \n \n \t\t// L S R \n \t\t// /--------------------------\\ \n \t\t//\t ||------------------------|| \n \t\t// || [][] || \n \t\t// || [] [] || \n \t\t// || [] [] || \n \t\t// || || \n \t\t// || || \n \t\t// || || \n \t\t// || || \n \t\t// || || \n \t\t// || [] [] || \n \t\t// || [] [] || \n \t\t// || [][] || \n \t\t// ||------------------------|| \n \t\t// \\--------------------------/ \n \t\t// \n \t\t// ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ ~ \n \n \t\tctrlThresh = .2; // the point at which we want to sense joystick action \n \t\trecip = 1-ctrlThresh; \t\t // = 0.8 \n \n \t\trightAxis = rightStick.getRawAxis(1);\t\t\t\t// right joystick, y (up/down) axis\n \t\t\n \t\t//System.out.println(\"\"+rightAxis);\n \t\tstrafeAxis = rightStick.getRawAxis(0);\t\t\t\t// right joystick, x (left/right) axis; this is \n \t\t\t\t\t\t\t\t\t\t\t\t\t\t\t/// arbitrary and could have been the left stick\n \t\trotateAxis = rightStick.getRawAxis(4);\t\t\t\t\t// left joystick, y axis\n \n \t\trightDir = rightAxis/Math.abs(rightAxis);\t\t\t// forward or backward (+1 or -1)\n \t\tstrafeDir = strafeAxis/Math.abs(strafeAxis); \t// \t\t\t'' \n \t\trotateDir = rotateAxis/Math.abs(rotateAxis); // \t\t\t'' \n \n \t\tright = 0; // right input formatted for range of detected values [0.2,1] \n \t\trotate = 0; // left input formatted \n \t\tstrafe = 0; // strafe input formatted \n \n \t\tif(Math.abs(rightAxis) > ctrlThresh) \t// user moved stick beyond threshold \n \t\t{right = (rightAxis-ctrlThresh*rightDir)/recip;} // format right: scale back, set direction, proportion it \n \t\tif(Math.abs(strafeAxis) > ctrlThresh) \n \t\t{strafe = (strafeAxis-ctrlThresh*strafeDir)/recip;} // format left... \n \t\tif(Math.abs(rotateAxis) > ctrlThresh) \n \t\t{rotate = (rotateAxis-ctrlThresh*rotateDir)/recip;}\t\t// format strafe... \n \n \n \t\trightDir = right/Math.abs(right); \n \t\trightPower = (Math.abs(right*mult) + minPower) * rightDir; \t\t// re-proportion for power's range, strip direction,\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t\t/// and then add back threshold and direction. \n \t\trotateDir = rotate/Math.abs(rotate); \n \t\trotatePower = (Math.abs(rotate*mult) + minPower) * rotateDir;\t\t\t// \t\t'' \n \n \t\tstrafeDir = strafe/Math.abs(strafe); \n \t\tstrafePower = (Math.abs(strafe*mult) + minPower) * strafeDir;\t// \t\t'' \n \n \t\tif(Math.abs(rightPower)>0.2){\n \t\t\tfrontRight.set(rightPower);\t\t\t\t\t\t// set all the motors with the powers we \n \t\t\tbackRight.set(rightPower);\t\t\t\t\t\t/// calculated above : drive! \n \t\t\tfrontLeft.set(-1*rightPower); \n \t\t\tbackLeft.set(-1*rightPower);\n \t\t}\n \t\telse{\n \t\t\tfrontRight.set(rotatePower);\n \t\t\tbackRight.set(rotatePower);\n \t\t\tfrontLeft.set(rotatePower);\n \t\t\tbackLeft.set(rotatePower);\n \t\t}\n \t\t\n// \t\tfrontStrafe.set(strafePower); \n// \t\tbackStrafe.set(-1*strafePower); \n \n// \t\tmyRobot.tankDrive(leftStick, rightStick); \n \t\t \n \t\t// ********** END OF DRIVING CODE ********** \n \t\t//======================================================================= \n \t\t// ************ BEGIN WINCH CODE *********** \n \t\t// We need to code the winch to help raise and lower the elevator \n \t\t// This is just one option between the winch and the lead screw. \n \t\t \n \t\t\n \t\t//second winch test\n \t\t/*\n \t\twinchCount = winchEncoder.get();\t\t\t\t// get the pulse count from the encoder\n \t \tSystem.out.println(\"Count: \"+ winchCount);\t\t// print the pulse count \n \t \tif(winchCount<240){\n \t \t\t\n \t \t\twinchCim1.set(.1);\n \t \t\twinchCim2.set(.1);\n \t \t}\n \t \telse{\n \t \t\twinchCim1.set(0);\n \t \t\twinchCim2.set(0);\n \t \t\t\n \t \t}\n \t if(rightStick.getRawButton(5)) \n { \n\t\t\t winchEncoder.reset();// reset the pulse count\n\t\t\t winchCount = 0;\n\t\t\t winchCim1.set(0);\n\t\t\t winchCim2.set(0);\n\t\t\t \n } */ //end of second winch test \n \t \t\n \t\t\n \t\t if(rightStick.getRawButton(5)) \n { \n \t\t\t //winchEncoder.reset();// reset the pulse count\n \tSystem.out.println(\"A\");\n \t winchCim1.set(.5); \t// set winchCim1 to 0.5 power (upwards) \n \t winchCim2.set(.5); \t\t\t\t\t\t\t// set winchCim2 to 0.5 power\n \t\t\t \n } \n \t\telse if(rightStick.getRawButton(4))\n \t\t{\n \t\t\tSystem.out.println(\"B\");\n \t\t\t//winchEncoder.reset();\t\t\t\t\t\t\t// reset the pulse count\n \t \twinchCim1.set(-.3); // set winchCim1 to -0.5 power (downwards) \n \t \twinchCim2.set(-.3);\t \t\t\t\t\t\t\t// set winchCim2 to -0.5 power\n \t\t}\n \n \t \telse// if(rightStick.getRawButton(2)) \n { \n \t winchCim1.set(0); \t\t\t\t\t\t\t// set winchCim1 to 0 power (off/stop) \n \t winchCim2.set(0);\t\t\t\t\t\t\t\t// set winchCim2 to 0 pwoer (off/stop)\n// \t winchCount = winchEncoder.get();\t\t\t\t// get the pulse count from the encoder\n// \t System.out.println(\"Count: \"+ winchCount);\t\t// print the pulse count \n } \n \n \t\t// ********** END OF WINCH CODE ********** \n \t\t//======================================================================= \n \t\t \n \t\t \n \t\tTimer.delay(0.005);\t\t// wait for a motor update time \n } \n }", "@Override\n\tpublic void onSensorChanged(SensorEvent se) {\n\t\teventIesim++;\n\t\tif(eventIesim == THRESHOLD_EVENTS)\n\t\t{\n\n\t\t\tswitch (se.sensor.getType())\n\t\t\t{\n\t\t\t\tcase Sensor.TYPE_ACCELEROMETER:\n\t\t\t\t{\n\t\t\t\t\taccelerometerValues = se.values.clone();\n\t\t\t\t\tnew ListenerThread(accelerometerValues,delta_orientation,context,gps).start(); // use the last orientation set\n\t\t\t\t\t\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t\tcase Sensor.TYPE_MAGNETIC_FIELD:\n\t\t\t\t{\n\t\t\t\t\tgeomagneticMatrix = se.values.clone();\n\t\t\t\t\tsensorReady = true;\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t\tdefault:\n\t\t\t\t\tbreak;\n\t\t\t} \n\n\t\t\tif (geomagneticMatrix != null && accelerometerValues != null && sensorReady) \n\t\t\t{\n\t\t\t\tsensorReady = false;\n\n\t\t\t\tfloat[] R = new float[16];\n\t\t\t\tfloat[] I = new float[16];\n\n\t\t\t\tSensorManager.getRotationMatrix(R, I, accelerometerValues, geomagneticMatrix);\n\n\t\t\t\tfloat[] actual_orientation = new float[3];\n\t\t\t\tSensorManager.getOrientation(R, actual_orientation); // lastorientation filled with orientation in radiant\n\t\t\t\t\n\t\t\t\tdelta_orientation[0]= (delta_orientation[0] > actual_orientation[0]) ? (delta_orientation[0] - actual_orientation[0]) : (actual_orientation[0] - delta_orientation[0]);\n\t\t\t\tdelta_orientation[1]= (delta_orientation[1] > actual_orientation[1]) ? (delta_orientation[1] - actual_orientation[1]) : (actual_orientation[1] - delta_orientation[1]);\n\t\t\t\tdelta_orientation[2]= (delta_orientation[2] > actual_orientation[2]) ? (delta_orientation[2] - actual_orientation[2]) : (actual_orientation[2] - delta_orientation[2]);\n\n\t\t\t\tLog.i(TAG, \"acceleration with gravity x:\"+accelerometerValues[0]+\" y:\"+accelerometerValues[1]+\" z:\"+accelerometerValues[2]);\n\n\t\t\t\tnew ListenerThread(accelerometerValues,delta_orientation,context,gps).start();\n\n\t\t\t\tLog.i(TAG, \"orientation x:\"+delta_orientation[0]+\" y:\"+delta_orientation[1]+\" z:\"+delta_orientation[2]);\n\t\t\t\t//Toast.makeText(context, \"orientation x:\"+delta_orientation[0]+\" y:\"+delta_orientation[1]+\" z:\"+delta_orientation[2], Toast.LENGTH_SHORT).show();\n\t\t\t\t\n\t\t\t\tdelta_orientation = actual_orientation;\n\t\t\t}\n\t\t\teventIesim = 0;\n\t\t}\n\t\t\n\n\n\t}", "@Override\n public void runOpMode() throws InterruptedException {\n distanceSensorInRange = false;\n myGlyphLift = new glyphLift(hardwareMap.dcMotor.get(\"glyph_lift\"));\n myColorSensorArm = new colorSensorArm(hardwareMap.servo.get(\"color_sensor_arm\"),hardwareMap.colorSensor.get(\"sensor_color\"), hardwareMap.servo.get(\"color_sensor_arm_rotate\"));\n myMechDrive = new mechDriveAuto(hardwareMap.dcMotor.get(\"front_left_motor\"), hardwareMap.dcMotor.get(\"front_right_motor\"), hardwareMap.dcMotor.get(\"rear_left_motor\"), hardwareMap.dcMotor.get(\"rear_right_motor\"));\n myGlyphArms = new glyphArms(hardwareMap.servo.get(\"top_left_glyph_arm\"), hardwareMap.servo.get(\"bottom_left_glyph_arm\"), hardwareMap.servo.get(\"top_left_glyph_arm\"), hardwareMap.servo.get(\"bottom_right_glyph_arm\"));\n myBoardArm = new boardArm(hardwareMap.dcMotor.get(\"board_arm\"));\n myRevColorDistanceSensor = new revColorDistanceSensor(hardwareMap.get(ColorSensor.class, \"rev_sensor_color_distance\"), hardwareMap.get(DistanceSensor.class, \"rev_sensor_color_distance\"));\n\n\n myColorSensorArm.colorSensorArmUpSlow();\n myColorSensorArm.colorRotateResting();\n //myGlyphArms.openRaisedGlyphArms(); //ensures robot is wihin 18\" by 18\" parameters\n\n int cameraMonitorViewId = hardwareMap.appContext.getResources().getIdentifier(\"cameraMonitorViewId\", \"id\", hardwareMap.appContext.getPackageName());\n VuforiaLocalizer.Parameters parameters = new VuforiaLocalizer.Parameters(cameraMonitorViewId);\n parameters.vuforiaLicenseKey = \"ASmjss3/////AAAAGQGMjs1d6UMZvrjQPX7J14B0s7kN+rWOyxwitoTy9i0qV7D+YGPfPeeoe/RgJjgMLabjIyRXYmDFLlJYTJvG9ez4GQSI4L8BgkCZkUWpAguRsP8Ah/i6dXIz/vVR/VZxVTR5ItyCovcRY+SPz3CP1tNag253qwl7E900NaEfFh6v/DalkEDppFevUDOB/WuLZmHu53M+xx7E3x35VW86glGKnxDLzcd9wS1wK5QhfbPOExe97azxVOVER8zNNF7LP7B+Qeticfs3O9pGXzI8lj3zClut/7aDVwZ10IPVk4oma6CO8FM5UtNLSb3sicoKV5QGiNmxbbOlnPxz9qD38UAHshq2/y0ZjI/a8oT+doCr\";\n parameters.cameraDirection = VuforiaLocalizer.CameraDirection.BACK;\n this.vuforia = ClassFactory.createVuforiaLocalizer(parameters);\n VuforiaTrackables relicTrackables = this.vuforia.loadTrackablesFromAsset(\"RelicVuMark\");\n VuforiaTrackable relicTemplate = relicTrackables.get(0);\n relicTemplate.setName(\"relicVuMarkTemplate\"); // can help in debugging; otherwise not necessary\n\n waitForStart();\n\n relicTrackables.activate();\n\n while (opModeIsActive()) {\n myGlyphArms.closeGlyphArms();\n sleep(2000);\n myMechDrive.vuforiaLeft(myGlyphArms);\n sleep(1000);\n requestOpModeStop();\n }\n }", "public void gyroDrive ( double speed,\n double distance,\n double angle) {\n\n\n // Ensure that the opmode is still activ\n\n // Determine new target position, and pass to motor controller\n moveCounts = (int)(distance * COUNTS_PER_INCH);\n newLeftTarget = leftmotor.getCurrentPosition() + moveCounts;\n newRightTarget = rightmotor.getCurrentPosition() + moveCounts;\n\n // Set Target and Turn On RUN_TO_POSITION\n leftmotor.setTargetPosition(newLeftTarget);\n rightmotor.setTargetPosition(newRightTarget);\n\n leftmotor.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n rightmotor.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n\n // start motion.\n speed = Range.clip(Math.abs(speed), 0.0, 1.0);\n\n maxSpeed = speed;\n speed = INCREMENT;\n rampUp = true;\n\n leftmotor.setPower(speed);\n rightmotor.setPower(speed);\n\n // keep looping while we are still active, and BOTH motors are running.\n while ((leftmotor.isBusy() && rightmotor.isBusy())) {\n if (rampUp){\n speed += INCREMENT ;\n if (speed >= maxSpeed ) {\n speed = maxSpeed;\n }\n }\n\n // adjust relative speed based on heading error.\n error = getError(angle);\n steer = getSteer(error, P_DRIVE_COEFF);\n\n // if driving in reverse, the motor correction also needs to be reversed\n if (distance < 0)\n steer *= -1.0;\n\n leftSpeed = speed - steer;\n rightSpeed = speed + steer;\n\n // Normalize speeds if either one exceeds +/- 1.0;\n max = Math.max(Math.abs(leftSpeed), Math.abs(rightSpeed));\n if (max > 1.0)\n {\n leftSpeed /= max;\n rightSpeed /= max;\n }\n\n leftmotor.setPower(leftSpeed);\n rightmotor.setPower(rightSpeed);\n }\n\n // Stop all motion;\n leftmotor.setPower(0);\n rightmotor.setPower(0);\n\n // Turn off RUN_TO_POSITION\n leftmotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n rightmotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n gyroHold(TURN_SPEED,angle,0.166);\n\n }", "public void runOpMode() throws InterruptedException {\n robot.init(hardwareMap);\n BNO055IMU.Parameters parameters1 = new BNO055IMU.Parameters();\n parameters1.angleUnit = BNO055IMU.AngleUnit.DEGREES;\n imu = hardwareMap.get(BNO055IMU.class, \"imu\");\n imu.initialize(parameters1);\n int cameraMonitorViewId = hardwareMap.appContext.getResources().getIdentifier(\"cameraMonitorViewId\", \"id\", hardwareMap.appContext.getPackageName());\n robot.arm.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.arm.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n //P.S. if you're using the latest version of easyopencv, you might need to change the next line to the following:\n phoneCam = OpenCvCameraFactory.getInstance().createInternalCamera(OpenCvInternalCamera.CameraDirection.BACK, cameraMonitorViewId);\n //phoneCam = new OpenCvInternalCamera(OpenCvInternalCamera.CameraDirection.BACK, cameraMonitorViewId);//remove this\n\n phoneCam.openCameraDevice();//open camera\n phoneCam.setPipeline(new StageSwitchingPipeline());//different stages\n phoneCam.startStreaming(rows, cols, OpenCvCameraRotation.SIDEWAYS_LEFT);//display on RC\n //width, height\n //width = height in this case, because camera is in portrait mode.\n\n runtime.reset();\n while (!isStarted()) {\n for (int i = 0; i <= 7; i++) {\n telemetry.addData(\"Values\", vals[i]);\n }\n for (int i = 0; i <= 7; i++) {\n totals = totals + vals[i];\n }\n totals = totals / 255;\n telemetry.addData(\"total\", totals);\n\n telemetry.addData(\"Height\", rows);\n telemetry.addData(\"Width\", cols);\n\n telemetry.update();\n sleep(100);\n\n if (totals >= 4) {\n StartAngle = 30;\n StartDistance = 105;\n StartBack = -40;\n ReturnAngle = 28;\n ReturnDistance = -85;\n drop2 = 112;\n mid = 0;\n backup2 = -33;\n } else if (totals <= 0) {\n StartAngle = 55;\n StartDistance= 85;\n StartBack = -5;\n ReturnAngle = 38;\n ReturnDistance = -60;\n drop2 = 65;\n mid = -2;\n backup2 = -31;\n } else {\n StartAngle = 17;\n StartDistance = 75;\n StartBack = -20;\n ReturnAngle = 22;\n ReturnDistance = -49;\n drop2 = 95;\n mid = -18;\n backup2 = -41;\n }\n totals = 0;\n }\n\n\n\n gyroDrive(DRIVE_SPEED,6,0,30,0);\n gyroDrive(DRIVE_SPEED,36,-45,30,0);\n gyroDrive(DRIVE_SPEED,StartDistance,StartAngle,30,0);\n\n //robot.arm.setTargetPosition(-450);\n //robot.arm.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n /*robot.arm.setPower(-.1);\n //robot.arm.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n gyroHold(DRIVE_SPEED,0,2);\n robot.claw.setPosition(0);\n robot.arm.setPower(.05);\n gyroHold(DRIVE_SPEED,0,1);\n gyroDrive(DRIVE_SPEED,-10,0,5,0);\n gyroTurn(TURN_SPEED,90);\n gyroDrive(DRIVE_SPEED,-20,90,5,0);\n\n */\n gyroTurn(TURN_SPEED,ReturnAngle);\n robot.LWheel.setPower(-.9);\n robot.RWheel.setPower(-.9);\n gyroDrive(DRIVE_SPEED, ReturnDistance,ReturnAngle, 30,0);\n gyroHold(TURN_SPEED,3,1);\n robot.lock.setPosition(1);\n robot.RTrack.setPosition(1);\n robot.LTrack.setPosition(0);\n gyroHold(TURN_SPEED,0,2);\n gyroHold(TURN_SPEED,-3,2);\n robot.LWheel.setPower(0);\n robot.RWheel.setPower(0);\n robot.RTrack.setPosition(.5);\n robot.LTrack.setPosition(.5);\n gyroTurn(TURN_SPEED,ReturnAngle);\n gyroDrive(DRIVE_SPEED, backup2, ReturnAngle, 30,0);\n\n gyroTurn(TURN_SPEED,90);\n gyroDrive(DRIVE_SPEED,52,80,5,0);\n gyroTurn(TURN_SPEED,65);\n gyroDrive(DRIVE_SPEED,drop2,2 + mid,10,0);\n robot.RDrop.setPosition(.23);\n robot.LDrop.setPosition(.23);\n gyroDrive(DRIVE_SPEED,StartBack,0,5,0);\n robot.arm.setPower(-.2);\n\n gyroHold(TURN_SPEED,0,1.7);\n robot.arm.setPower(0);\n }", "public void run() {\n\n EV3ColorSensor sensor = new EV3ColorSensor(usPort); // usSensor is the instance\n SampleProvider sensorProvider = sensor.getMode(\"Red\");\n MeanFilter filter = new MeanFilter(sensorProvider, 4);\n float[] sample = new float[sensor.sampleSize()];\n boolean inLine = false; // Flags whether the sensor is currently seeing a line\n boolean makeCorrection = false; // Tells the class to correct the odometer values\n double[] position = odometer.getXYT(); // Current odometer values\n Direction direction = Direction.INIT; // Direction of the robot's movement\n\n long correctionStart, correctionEnd;\n\n while (true) {\n correctionStart = System.currentTimeMillis();\n\n // Trigger correction (When do I have information to correct?)\n filter.fetchSample(sample, 0);\n boolean lineDetected = sample[0] < LINE_COLOR_VALUE;\n\n if (lineDetected) {\n if (!inLine) {\n inLine = true;\n makeCorrection = true;\n lineCount++;\n Sound.beep();\n }\n } else\n inLine = false;\n\n // Calculate new (accurate) robot position\n if (makeCorrection && lineCount < ((SQUARE_SIZE - 1) * 4)) {\n makeCorrection = false;\n position = odometer.getXYT();\n\n // Get the direction of movement according to the angle\n double theta = position[2];\n if (theta > 45 && theta < 135) {\n direction = Direction.EAST;\n } else if (theta > 135 && theta < 225) {\n direction = Direction.SOUTH;\n } else if (theta > 225 && theta < 315) {\n direction = Direction.WEST;\n } else {\n direction = Direction.NORTH;\n }\n\n // Update odometer with new calculated (and more accurate) vales\n double correctedX, correctedY;\n switch (direction) {\n case NORTH:\n correctedY = (YN * TILE_SIZE) - SENSOR_OFFSET;\n YN++;\n odometer.setXYT(position[0], correctedY, position[2]);\n // System.out.println(\"Correcting Y to: \" + correctedY);\n break;\n case EAST:\n correctedX = (XE * TILE_SIZE) - SENSOR_OFFSET;\n XE++;\n odometer.setXYT(correctedX, position[1], position[2]);\n // System.out.println(\"Correcting X to: \" + correctedX);\n break;\n case SOUTH:\n YS--;\n correctedY = (YS * TILE_SIZE) + SENSOR_OFFSET;\n odometer.setXYT(position[0], correctedY, position[2]);\n // System.out.println(\"Correcting Y to: \" + correctedY);\n break;\n case WEST:\n XW--;\n correctedX = (XW * TILE_SIZE) + SENSOR_OFFSET;\n odometer.setXYT(correctedX, position[1], position[2]);\n // System.out.println(\"Correcting X to: \" + correctedX);\n break;\n }\n }\n\n // this ensure the odometry correction occurs only once every period\n correctionEnd = System.currentTimeMillis();\n if (correctionEnd - correctionStart < CORRECTION_PERIOD) {\n try {\n Thread.sleep(CORRECTION_PERIOD - (correctionEnd - correctionStart));\n } catch (InterruptedException e) {\n // there is nothing to be done here\n }\n }\n }\n }", "private void processGyroData(SensorEvent event){\n //interval between two data entry should be min SENSOR_DATA_MIN_INTERVAL which is millis\n if ((event.timestamp - lastUpdateGyro) < SENSOR_DATA_MIN_INTERVAL_NANOS) { //multiply to convert to millis from nanos\n return;\n }\n\n\n float[] values = event.values;\n\n float axis_x = values[0];\n float axis_y = values[1];\n float axis_z = values[2];\n\n //float gyroscopeRotationVelocity = (float)Math.sqrt(axis_x * axis_x + axis_y * axis_y + axis_z * axis_z);\n //magnitude of gyroscope reading thresholded\n\n //if(gyroscopeRotationVelocity > EPSILON){\n lastUpdateGyro = event.timestamp;\n long timestamp = Util.getStartTime() + event.timestamp/Const.NANOS_TO_MILLIS;\n saveGyroData(axis_x, axis_y, axis_z, timestamp);\n //}\n }", "public boolean addGyro() {\n if (getEmptyCriticals(LOC_CT) < 4) {\n return false;\n }\n addCompactGyro();\n addCritical(LOC_CT, 5, new CriticalSlot(CriticalSlot.TYPE_SYSTEM, SYSTEM_GYRO));\n addCritical(LOC_CT, 6, new CriticalSlot(CriticalSlot.TYPE_SYSTEM, SYSTEM_GYRO));\n setGyroType(GYRO_STANDARD);\n return true;\n }", "public void autonomous() {\n /*myRobot.setSafetyEnabled(false);\n myRobot.drive(-0.5, 0.0);\t// drive forwards half speed\n Timer.delay(2.0);\t\t// for 2 seconds\n myRobot.drive(0.0, 0.0);\t// stop robot\n */\n \t/*gyro.reset();\n \twhile(isAutonomous()){\n \t\tdouble angle = gyro.getAngle();\n \tmyRobot.drive(0, -angle * Kp);\t\n \tTimer.delay(.004);\n \t}\n \tmyRobot.drive(0.0, 0.0);\n \t*/\n }", "@Override\n public void loop() {\n telemetry.addData(\"Status\", \"Running: \" + runtime.toString());\n\n //zAccumulated = mrGyro.getIntegratedZValue(); //Set variables to gyro readings\n\n heading = 360 - mrGyro.getHeading(); //Reverse direction of heading to match the integrated value\n if (heading == 360)\n {\n heading = 0;\n }\n\n xVal = mrGyro.rawX() / 128; //Lowest 7 bits are noise\n yVal = mrGyro.rawY() / 128;\n zVal = mrGyro.rawZ() / 128;\n\n //The below two if() statements ensure that the mode of the color sensor is changed only once each time the touch sensor is pressed.\n //The mode of the color sensor is saved to the sensor's long term memory. Just like flash drives, the long term memory has a life time in the 10s or 100s of thousands of cycles.\n //This seems like a lot but if your program wrote to the long term memory every time though the main loop, it would shorten the life of your sensor.\n\n if (!buttonState && gamepad1.x) { //If the touch sensor is just now being pressed (was not pressed last time through the loop but now is)\n buttonState = true; //Change touch state to true because the touch sensor is now pressed\n LEDState = !LEDState; //Change the LEDState to the opposite of what it was\n if(LEDState)\n {\n BallSensorreader.write8(3, 0); //Set the mode of the color sensor using LEDState\n }\n else\n {\n BallSensorreader.write8(3, 1); //Set the mode of the color sensor using LEDState\n }\n }\n\n if (!gamepad1.x) //If the touch sensor is now pressed\n buttonState = false; //Set the buttonState to false to indicate that the touch sensor was released\n\n BallSensorcache = BallSensorreader.read(0x04, 1);\n\n if (gamepad2.a)\n liftSpeed = 1;\n if (gamepad2.b)\n liftSpeed = 0.5;\n\n driveSpeed = 1;\n\n if (gamepad1.right_bumper)\n driveSpeed = 0.5;\n\n if (gamepad1.left_bumper)\n driveSpeed = 0.25;\n\n // Run wheels in tank mode (note: The joystick goes negative when pushed forwards, so negate it)\n frontLeft = ( gamepad1.left_stick_x - gamepad1.left_stick_y - gamepad1.right_stick_x)/2 * driveSpeed; //Front right\n frontRight = ( gamepad1.left_stick_x + gamepad1.left_stick_y - gamepad1.right_stick_x)/2 * driveSpeed; //Front left\n backLeft = (-gamepad1.left_stick_x - gamepad1.left_stick_y - gamepad1.right_stick_x)/2 * driveSpeed; //Back right\n backRight = (-gamepad1.left_stick_x + gamepad1.left_stick_y - gamepad1.right_stick_x)/2 * driveSpeed; //Back left\n Lift = gamepad2.left_stick_y * liftSpeed;\n\n robot.FL_drive.setPower(frontLeft);\n robot.FR_drive.setPower(frontRight);\n robot.BL_drive.setPower(backLeft);\n robot.BR_drive.setPower(backRight);\n robot.Lift.setPower(Lift);\n\n // Left servo going in means more\n if (gamepad2.left_bumper)\n leftPosition += LEFT_SPEED;\n else if (gamepad2.y)\n leftPosition = LEFT_MIN_RANGE;\n\n // Right servo going in means less\n if (gamepad2.right_bumper)\n rightPosition -= RIGHT_SPEED;\n else if (gamepad2.y)\n rightPosition = RIGHT_MAX_RANGE;\n\n if (gamepad2.x)\n {\n rightPosition = 0.96;\n leftPosition = 0.44;\n }\n\n if (gamepad1.a)\n target = target + 45;\n if (gamepad1.b)\n target = target - 45;\n\n //turnAbsolute(target);\n\n // Move both servos to new position.\n leftPosition = Range.clip(leftPosition, robot.LEFT_MIN_RANGE, robot.LEFT_MAX_RANGE);\n robot.Left.setPosition(leftPosition);\n rightPosition = Range.clip(rightPosition, robot.RIGHT_MIN_RANGE, robot.RIGHT_MAX_RANGE);\n robot.Right.setPosition(rightPosition);\n\n // Send telemetry message to signify robot running;\n telemetry.addData(\"Left\", \"%.2f\", leftPosition);\n telemetry.addData(\"Right\", \"%.2f\", rightPosition);\n telemetry.addData(\"frontLeft\", \"%.2f\", frontLeft);\n telemetry.addData(\"frontRight\", \"%.2f\", frontRight);\n telemetry.addData(\"backLeft\", \"%.2f\", backLeft);\n telemetry.addData(\"backRight\", \"%.2f\", backRight);\n telemetry.addData(\"Lift\", \"%.2f\", Lift);\n\n //display values\n telemetry.addData(\"1 #A\", BallSensorcache[0] & 0xFF);\n\n telemetry.addData(\"3 A\", BallSensorreader.getI2cAddress().get8Bit());\n\n telemetry.addData(\"1. heading\", String.format(\"%03d\", heading)); //Display variables to Driver Station Screen\n telemetry.addData(\"2. target\", String.format(\"%03d\", target));\n telemetry.addData(\"3. X\", String.format(\"%03d\", xVal));\n telemetry.addData(\"4. Y\", String.format(\"%03d\", yVal));\n telemetry.addData(\"5. Z\", String.format(\"%03d\", zVal));\n\n telemetry.update(); //Limited to 100x per second\n\n }", "public void init() {\n delayingTimer = new ElapsedTime();\n\n // Define and Initialize Motors and Servos: //\n tailMover = hwMap.dcMotor.get(\"tail_lift\");\n grabberServo = hwMap.servo.get(\"grabber_servo\");\n openGrabber();\n\n // Set Motor and Servo Directions: //\n tailMover.setDirection(DcMotorSimple.Direction.FORWARD);\n\n tailMover.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n tailMover.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n int prevEncoder = tailMover.getCurrentPosition();\n tailMover.setPower(-0.15);\n mainHW.opMode.sleep (300);\n Log.d(\"catbot\", String.format(\"tail lift power %.2f current position %2d prev %2d\", tailMover.getPower(), tailMover.getCurrentPosition(),prevEncoder));\n runtime.reset();\n while((Math.abs(prevEncoder - tailMover.getCurrentPosition()) > 10)&& (runtime.seconds()<3.0)){\n prevEncoder = tailMover.getCurrentPosition();\n mainHW.opMode.sleep(300);\n Log.d(\"catbot\", String.format(\"tail lift power %.2f current position %2d prev %2d\", tailMover.getPower(), tailMover.getCurrentPosition(),prevEncoder));\n }\n tailMover.setPower(0.0);\n // Set Motor and Servo Modes: //\n tailMover.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n\n tailMover.setTargetPosition(0);\n tailMover.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n closeGrabber();\n }", "public void testGyroAngleCalibratedParameters() {\n // Get calibrated parameters to make new Gyro with parameters\n final double calibratedOffset = m_tpcam.getGyro().getOffset();\n final int calibratedCenter = m_tpcam.getGyro().getCenter();\n m_tpcam.freeGyro();\n m_tpcam.setupGyroParam(calibratedCenter, calibratedOffset);\n Timer.delay(TiltPanCameraFixture.RESET_TIME);\n // Repeat tests\n testInitial(m_tpcam.getGyroParam());\n testDeviationOverTime(m_tpcam.getGyroParam());\n testGyroAngle(m_tpcam.getGyroParam());\n }", "@Override\n public void robotInit() {\n m_chooser.setDefaultOption(\"Default Auto\", kDefaultAuto);\n m_chooser.addOption(\"My Auto\", kCustomAuto);\n SmartDashboard.putData(\"Auto choices\", m_chooser);\n\n /* lets grab the 360 degree position of the MagEncoder's absolute position */\n /* mask out the bottom12 bits, we don't care about the wrap arounds */ \n\t\tint absolutePosition = elevator.getSelectedSensorPosition(0) & 0xFFF;\n \n /* use the low level API to set the quad encoder signal */\n elevator.setSelectedSensorPosition(absolutePosition, Constants.kPIDLoopIdx, Constants.kTimeoutMs);\n\n /* choose the sensor and sensor direction */\n elevator.configSelectedFeedbackSensor(FeedbackDevice.CTRE_MagEncoder_Relative, \n Constants.kPIDLoopIdx, Constants.kTimeoutMs);\n\n /* Ensure sensor is positive when output is positive */\n elevator.setSensorPhase(false);\n\n /**\n * Set based on what direction you want forward/positive to be.\n * This does not affect sensor phase. \n */ \n //elevator.setInverted(Constants.kMotorInvert);\n \n /* Config the peak and nominal outputs, 12V means full */\n elevator.configNominalOutputForward(0, Constants.kTimeoutMs);\n elevator.configNominalOutputReverse(0, Constants.kTimeoutMs);\n //elevator.configPeakOutputForward(1, Constants.kTimeoutMs);\n elevator.configNominalOutputForward(0.5);\n //elevator.configPeakOutputForward(1, Constants.kTimeoutMs);\n elevator.configPeakOutputForward(0.5);\n elevator.configPeakOutputReverse(-1, Constants.kTimeoutMs);\n \n /**\n * Config the allowable closed-loop error, Closed-Loop output will be\n * neutral within this range. See Table in Section 17.2.1 for native\n * units per rotation.\n */\n //elevator.configAllowableClosedloopError(0, Constants.kPIDLoopIdx, Constants.kTimeoutMs);\n \n /* Config Position Closed Loop gains in slot0, typically kF stays zero. */\n elevator.config_kF(Constants.kPIDLoopIdx, 0.0, Constants.kTimeoutMs);\n elevator.config_kP(Constants.kPIDLoopIdx, 0.5, Constants.kTimeoutMs);\n elevator.config_kI(Constants.kPIDLoopIdx, 0.0, Constants.kTimeoutMs);\n elevator.config_kD(Constants.kPIDLoopIdx, 0.0, Constants.kTimeoutMs);\n\n\n }", "public void gyroHold(double speed, double angle, double holdTime) {\n\n ElapsedTime holdTimer = new ElapsedTime();\n\n // keep looping while we have time remaining.\n holdTimer.reset();\n while (opModeIsActive() && (holdTimer.time() < holdTime)) {\n // Update telemetry & Allow time for other processes to run.\n onHeading(speed, angle, P_TURN_COEFF);\n //telemetry.update();\n }\n\n // Stop all motion;\n robot.DriveLeft1.setPower(0);\n robot.DriveRight1.setPower(0);\n robot.DriveLeft2.setPower(0);\n robot.DriveRight2.setPower(0);\n }", "public void runOpMode(){\n JAWLDrive3796 drive = new JAWLDrive3796(hardwareMap.dcMotor.get(\"left_drive\"), hardwareMap.dcMotor.get(\"right_drive\"));\n //Set the drive motors to run without encoders\n drive.setEncoders(false);\n //Create Grabber object\n JAWLGrabber3796 grabber = new JAWLGrabber3796(hardwareMap.servo.get(\"left_arm\"), hardwareMap.servo.get(\"right_arm\"));\n //Create Lift object\n JAWLLift3796 lift = new JAWLLift3796(hardwareMap.dcMotor.get(\"lift_motor\"));\n //Create color arm object\n JAWLColorArm3796 colorArm = new JAWLColorArm3796(hardwareMap.servo.get(\"color_arm\"));\n //Creates color sensor name\n ColorSensor colorSensorTemp = hardwareMap.get(ColorSensor.class, \"color_distance\");\n //Creates distance sensor name\n DistanceSensor distanceSensorTemp = hardwareMap.get(DistanceSensor.class, \"color_distance\");\n //Creates the color-distance sensor object\n JAWLColorSensor3796 colorDistanceSensor = new JAWLColorSensor3796(colorSensorTemp, distanceSensorTemp);\n //Creates the variable that will hold the color of the jewel\n String colorOfBall;\n //Creates relic arm objects\n //TTTTRelicArm3796 relicArm = new TTTTRelicArm3796(hardwareMap.dcMotor.get(\"relic_up_down\"), hardwareMap.dcMotor.get(\"relic_out_in\"), hardwareMap.dcMotor.get(\"relic_grab\"));\n //We never ended up having a relic arm!\n //The lift helper will set the idle power of the motor to a small double, keeping the lift from idly falling down\n boolean liftHelper = false;\n int i = 0;\n\n waitForStart();\n\n colorArm.armUp();\n\n while (opModeIsActive()) {\n //Here is where we define how the controllers should work\n //In theory, no logic retaining to controlling the components should be in here\n\n /*\n * Drive\n */\n\n //The left drive wheel is controlled by the opposite value of the left stick's y value on the first gamepad\n //The right drive is the same way except with the right drive wheel\n drive.leftDrive(-gamepad1.left_stick_y);\n drive.rightDrive(-gamepad1.right_stick_y);\n\n /*\n * Lift\n */\n telemetry.addData(\"Gamepad2 Right Stick Y\", -gamepad2.right_stick_y);\n\n if (-gamepad2.right_stick_y > 0) {\n //First checks to see if the right stick's negative y value is greater then zero.\n lift.moveMotor(-gamepad2.right_stick_y);\n //If it is, it sets the power for the motor to 1, and adds telemetry\n telemetry.addData(\"Lift Power\", 1);\n } else if (-gamepad2.right_stick_y < 0) {\n //Checks if the negative value of the right right stick's y position is less than zero\n lift.moveMotor(-0.1);\n //Sets the power for the motor to -0.1, and adds telemetry\n telemetry.addData(\"Lift Power\", -0.1);\n } else {\n //We check to see if the liftHelper is enabled\n if(liftHelper) {\n lift.moveMotor(0.1466 );\n } else {\n lift.moveMotor(0);\n }\n }\n\n\n\n /*\n * Lift helper control\n */\n\n if(gamepad2.a) {\n if(i == 0) {\n liftHelper = !liftHelper;\n }\n i = 5;\n }\n\n if(i != 0) {\n i--;\n }\n\n telemetry.addData(\"Lift Helper Enabled\", liftHelper);\n\n\n\n /*\n * Grabbers\n */\n if (gamepad2.left_trigger > 0) {\n //Closes the left arm, then displays the position in telemetry\n grabber.leftArmClose();\n double a = grabber.leftPosition();\n //Adds telemetry to display positions of grabbers, mostly for testing, but can be useful later on\n telemetry.addData(\"Left\", a);\n }\n\n if (gamepad2.left_bumper) {\n //Opens the left arm, then displays the position in telemetry\n grabber.leftArmOpen();\n double b = grabber.leftPosition();\n //We made the variables different as to avoid any and all possible errors\n telemetry.addData(\"Left\", b);\n }\n\n if (gamepad2.right_trigger > 0) {\n //Opens the right arm, then displays the position in telemetry\n grabber.rightArmClose();\n double c = grabber.rightPosition();\n telemetry.addData(\"Right\", c);\n }\n\n if (gamepad2.right_bumper) {\n //Closes the right arm, then displays the position in telemetry\n grabber.rightArmOpen();\n double d = grabber.rightPosition();\n telemetry.addData(\"Right\", d);\n }\n\n if (gamepad2.dpad_left){\n //Closes the left arm to a shorter distance\n grabber.leftArmShort();\n }\n\n if(gamepad2.dpad_right){\n //Closes the right arm to a shorter distance\n grabber.rightArmShort();\n\n }\n\n //Update all of our telemetries at once so we can see all of it at the same time\n telemetry.update();\n }\n }", "public void resetGyro () {\n gyro.reset();\n }", "@Override\n public void periodic() {\n m_odometry.update(\n Rotation2d.fromDegrees(m_gyro.getAngle()),\n new SwerveModulePosition[] {\n m_frontLeft.getPosition(),\n m_frontRight.getPosition(),\n m_rearLeft.getPosition(),\n m_rearRight.getPosition()\n });\n }", "@Override\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Simple Ready to run\"); //\n telemetry.update();\n telemetry.addData(\"Status\", \"Initialized\");\n\n /**\n * Initializes the library functions\n * Robot hardware and motor functions\n */\n robot = new Robot_1617(hardwareMap);\n motorFunctions = new MotorFunctions(-1, 1, 0, 1, .05);\n\n //servo wheels are flipped in configuration file\n robot.servoLeftWheel.setPosition(.45);\n robot.servoRightWheel.setPosition(.25);\n\n robot.servoLeftArm.setPosition(0);\n robot.servoRightArm.setPosition(0.7);\n\n robot.servoFlyAngle.setPosition(1);\n\n robot.servoElbow.setPosition(0.95);\n robot.servoShoulder.setPosition(0.1);\n\n robot.servoFeed.setPosition(.498);\n\n robot.servoPlaid.setPosition(.85);\n\n telemetry.addData(\"Servos: \", \"Initialized\");\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n sleep(5000);\n robot.motorLift.setPower(0);\n robot.servoFlyAngle.setPosition(0);\n sleep(500);\n robot.motorFlyLeft.setPower(.9);\n robot.motorFlyRight.setPower(1);\n sleep(250);\n robot.motorIntakeElevator.setPower(1);\n robot.servoFeed.setPosition(-1);\n telemetry.addData(\"Status\", \"Shooting\"); //\n telemetry.update();\n sleep(5000);\n robot.motorFlyLeft.setPower(0);\n robot.motorFlyRight.setPower(0);\n// sleep(5000); //no idea why this is here\n robot.motorIntakeElevator.setPower(0);\n robot.servoFeed.setPosition(.1);\n sleep(250);\n\n telemetry.addData(\"Status\", \"Driving\");\n telemetry.update();\n encoderDrive(1.0, 30, 30, 1);\n\n encoderDrive(1.0, 35, 35, 1);\n }", "@Override\n public void teleopPeriodic() {\n CommandScheduler.getInstance().run();\n OI.getInstance().getPilot().run();\n SmartDashboard.putNumber(\"gyro\", getRobotContainer().getTecbotSensors().getYaw());\n SmartDashboard.putBoolean(\"isSpeed\", getRobotContainer().getDriveTrain().getTransmissionMode() == DriveTrain.TransmissionMode.speed);\n SmartDashboard.putString(\"DT_MODE\", getRobotContainer().getDriveTrain().getCurrentDrivingMode().toString());\n SmartDashboard.putNumber(\"x_count\", getRobotContainer().getClimber().getxWhenPressedCount());\n\n }", "@Override\n public void robotInit() {\n m_oi = new OI();\n m_chooser.setDefaultOption(\"Default Auto\", new ExampleCommand());\n // chooser.addOption(\"My Auto\", new MyAutoCommand());\n SmartDashboard.putData(\"Auto mode\", m_chooser);\n\n Comp = new Compressor();\n\n //ClimbBack = new DoubleSolenoid(PCM_COMP_24V, 0, 1);\n //ClimbFront = new DoubleSolenoid(PCM_COMP_24V, 2, 3);\n LegFrontL = new VictorSPX(30);\n LegFrontR = new Spark(9);\n LegBackL = new VictorSPX(31);\n LegBackR = new VictorSPX(32);\n\n BackFootMover = new VictorSP(1);\n FrontFootMover = new Spark(2);\n //FeetMovers = new SpeedControllerGroup(BackFootMoverFootMover);\n\n MainRight = new CANSparkMax(9, MotorType.kBrushless);\n AltRight = new CANSparkMax(10, MotorType.kBrushless);\n MainLeft = new CANSparkMax(11, MotorType.kBrushless);\n AltLeft = new CANSparkMax(12, MotorType.kBrushless);\n\n MainRight.setIdleMode(IdleMode.kCoast);\n AltRight.setIdleMode(IdleMode.kCoast);\n MainLeft.setIdleMode(IdleMode.kCoast);\n AltLeft.setIdleMode(IdleMode.kCoast);\n\n AltLeft.follow(MainLeft);\n AltRight.follow(MainRight);\n\n Drive = new DifferentialDrive(MainLeft, MainRight);\n\n Lifter = new TalonSRX(6);\n Lifter.setNeutralMode(NeutralMode.Brake);\n Lifter.enableCurrentLimit(false);\n /*Lifter.configContinuousCurrentLimit(40);\n Lifter.configPeakCurrentLimit(50);\n Lifter.configPeakCurrentDuration(1500);*/\n //Lifter.configReverseSoftLimitEnable(true);\n //Lifter.configReverseSoftLimitThreshold(-27000);\n //Lifter.configForwardLimitSwitchSource(LimitSwitchSource.FeedbackConnector, LimitSwitchNormal.NormallyOpen);\n //Lifter.configClearPositionOnLimitF(true, 0);\n Lifter.selectProfileSlot(0, 0);\n LiftSetpoint = 0;\n\n LiftFollower = new TalonSRX(5);\n LiftFollower.follow(Lifter);\n LiftFollower.setNeutralMode(NeutralMode.Brake);\n\n ArmExtender = new Solenoid(0);\n ArmOpener = new Solenoid(1);\n ArmGrippers = new Spark(0);\n\n HatchSwitch0 = new DigitalInput(0);\n HatchSwitch1 = new DigitalInput(1);\n\n Accel = new BuiltInAccelerometer(Range.k2G);\n\n //Diagnostics = new DiagnosticsLogger();\n // Uncomment this line to enable diagnostics. Warning: this may\n // cause the robot to be slower than it is supposed to be because of lag.\n //Diagnostics.start();\n\n xbox = new XboxController(0);\n joystick = new Joystick(1);\n \n LiftRamp = new SRamp();\n SpeedRamp = new SRamp();\n\n NetworkTableInstance nt = NetworkTableInstance.getDefault();\n\n VisionTable = nt.getTable(\"ChickenVision\");\n TapeDetectedEntry = VisionTable.getEntry(\"tapeDetected\");\n TapePitchEntry = VisionTable.getEntry(\"tapePitch\");\n TapeYawEntry = VisionTable.getEntry(\"tapeYaw\");\n\n LedTable = nt.getTable(\"LedInfo\");\n LedScript = LedTable.getEntry(\"CurrentScript\");\n LedScriptArgument = LedTable.getEntry(\"ScriptArgument\");\n LedArmsClosed = LedTable.getEntry(\"ArmsClosed\");\n\n UsbCamera cam = CameraServer.getInstance().startAutomaticCapture();\n cam.setPixelFormat(PixelFormat.kMJPEG);\n cam.setResolution(320, 240);\n cam.setFPS(15);\n \n\n LedScript.setString(\"ColorWaves\");\n LedScriptArgument.setString(\"\");\n\n limits = new DigitalInput[8];\n\n for (int i = 0; i < limits.length; i++) {\n limits[i] = new DigitalInput(i + 2);\n }\n }", "public void initialize() {\n\n Robot.driveSubsystem.resetGyro();\n\n }", "@Override\n public void gyroRoll(int value, int timestamp) {\n }", "public Drive() {\r\n \tgyro.calibrate();\r\n \tgyro.reset();\r\n }", "@Override\n public void gyroPitch(int value, int timestamp) {\n }", "public void runOpMode() {\n robot.init(hardwareMap);\n\n // Send telemetry message to signify robot waiting;\n telemetry.addData(\"Status\", \"Resetting Encoders\"); //\n telemetry.update();\n\n robot.leftMotor.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.rightMotor.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n idle();\n\n robot.leftMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n robot.rightMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n // Send telemetry message to indicate successful Encoder reset\n telemetry.addData(\"Path0\", \"Starting at %7d :%7d\",\n robot.leftMotor.getCurrentPosition(),\n robot.rightMotor.getCurrentPosition());\n telemetry.addData(\"Gyro Heading:\", \"%.4f\", getHeading());\n telemetry.update();\n\n int cameraMonitorViewId = hardwareMap.appContext.getResources().getIdentifier(\"cameraMonitorViewId\", \"id\", hardwareMap.appContext.getPackageName());\n\n VuforiaLocalizer.Parameters parameters = new VuforiaLocalizer.Parameters(cameraMonitorViewId);\n\n parameters.vuforiaLicenseKey = \"Adiq0Gb/////AAAAme76+E2WhUFamptVVqcYOs8rfAWw8b48caeMVM89dEw04s+/mRV9TqcNvLkSArWax6t5dAy9ISStJNcnGfxwxfoHQIRwFTqw9i8eNoRrlu+8X2oPIAh5RKOZZnGNM6zNOveXjb2bu8yJTQ1cMCdiydnQ/Vh1mSlku+cAsNlmfcL0b69Mt2K4AsBiBppIesOQ3JDcS3g60JeaW9p+VepTG1pLPazmeBTBBGVx471G7sYfkTO0c/W6hyw61qmR+y7GJwn/ECMmXZhhHkNJCmJQy3tgAeJMdKHp62RJqYg5ZLW0FsIh7cOPRkNjpC0GmMCMn8AbtfadVZDwn+MPiF02ZbthQN1N+NEUtURP0BWB1CmA\";\n\n\n parameters.cameraDirection = VuforiaLocalizer.CameraDirection.FRONT;\n this.vuforia = ClassFactory.createVuforiaLocalizer(parameters);\n\n VuforiaTrackables relicTrackables = this.vuforia.loadTrackablesFromAsset(\"RelicVuMark\");\n VuforiaTrackable relicTemplate = relicTrackables.get(0);\n relicTemplate.setName(\"relicVuMarkTemplate\"); // can help in debugging; otherwise not necessary\n\n telemetry.addData(\">\", \"Press Play to start\");\n telemetry.update();\n\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n relicTrackables.activate();\n\n //while (opModeIsActive()) {\n\n /**\n * See if any of the instances of {@link relicTemplate} are currently visible.\n * {@link RelicRecoveryVuMark} is an enum which can have the following values:\n * UNKNOWN, LEFT, CENTER, and RIGHT. When a VuMark is visible, something other than\n * UNKNOWN will be returned by {@link RelicRecoveryVuMark#from(VuforiaTrackable)}.\n */\n RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.from(relicTemplate);\n while (vuMark == RelicRecoveryVuMark.UNKNOWN) {\n vuMark = RelicRecoveryVuMark.from(relicTemplate);\n /* Found an instance of the template. In the actual game, you will probably\n * loop until this condition occurs, then move on to act accordingly depending\n * on which VuMark was visible. */\n }\n telemetry.addData(\"VuMark\", \"%s visible\", vuMark);\n telemetry.update();\n sleep(550);\n\n //switch (vuMark) {\n // case LEFT: //RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.LEFT;\n // coLumn = 2;\n // case CENTER:// RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.CENTER;\n // coLumn = 1;\n // case RIGHT:// RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.RIGHT;\n // coLumn = 0;\n //}\n if ( vuMark == RelicRecoveryVuMark.LEFT) {\n coLumn = 2;\n }\n else if(vuMark == RelicRecoveryVuMark.RIGHT){\n coLumn = 0;\n }\n else if(vuMark == RelicRecoveryVuMark.CENTER){\n coLumn = 1;\n }\n\n\n telemetry.addData(\"coLumn\", \"%s visible\", coLumn);\n telemetry.update();\n sleep(550);\n\n\n\n//if jewej is red 1 if jewel is blue 2\n\n // if(jewel == 1) {\n // gyroturn(-10, TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //gyroturn(-2, -TURN_SPEED, TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //}\n //else if(jewel == 2){\n // gyroturn(10, -TURN_SPEED, TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n // gyroturn(-2, TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //}\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[0][coLumn], disandTurn[0][coLumn], 5.0); // S1: Forward 24 Inches with 5 Sec timeout shoot ball\n\n gyroturn(disandTurn[1][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[0], -turndistance[0], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[2][coLumn], disandTurn[2][coLumn], 5.0); // S3: Forward 43.3 iNCHES\n\n gyroturn(disandTurn[3][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[4][coLumn], disandTurn[4][coLumn], 5.0);// S5: Forward 12 Inches with 4 Sec timeout\n\n gyroturn(disandTurn[5][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[6][coLumn], disandTurn[6][coLumn], 5.0);// S5: Forward 12 Inches with 4 Sec timeout\n\n\n Outake();\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[7][coLumn], disandTurn[7][coLumn], 5.0);// S6: Forward 48 inches with 4 Sec timeout\n }", "@Override\n public void init() {\n /* Initialize the hardware variables.\n * The init() method of the hardware class does all the work here\n */\n robot.init(hardwareMap);\n\n telemetry.addData(\"Status\", \"Initialized\");\n\n //the below lines set up the configuration file\n BallSensor = hardwareMap.i2cDevice.get(\"BallSensor\");\n\n BallSensorreader = new I2cDeviceSynchImpl(BallSensor, I2cAddr.create8bit(0x3a), false);\n\n BallSensorreader.engage();\n\n sensorGyro = hardwareMap.gyroSensor.get(\"gyro\"); //Point to the gyro in the configuration file\n mrGyro = (ModernRoboticsI2cGyro)sensorGyro; //ModernRoboticsI2cGyro allows us to .getIntegratedZValue()\n mrGyro.calibrate(); //Calibrate the sensor so it knows where 0 is and what still is. DO NOT MOVE SENSOR WHILE BLUE LIGHT IS SOLID\n\n //touch = hardwareMap.touchSensor.get(\"touch\");\n // Send telemetry message to signify robot waiting;\n telemetry.addData(\"Say\", \"Hello Driver\"); //\n telemetry.update();\n\n }", "@Override\n\tpublic void robotInit() //starts once when the code is started\n\t{\n\t\tm_oi = new OI(); //further definition of OI\n\t\t\n\t\t// chooser.addObject(\"My Auto\", new MyAutoCommand());\n\t\t//SmartDashboard.putData(\"Auto mode\", m_chooser);\n\t\t\n\t\tnew Thread(() -> {\n\t\t\tUsbCamera camera1 = CameraServer.getInstance().startAutomaticCapture();\n\t\t\tcamera1.setResolution(640, 480);\n\t\t\tcamera1.setFPS(30);\n\t\t\tcamera1.setExposureAuto();\n\t\t\t\n\t\t\tCvSink cvSink = CameraServer.getInstance().getVideo();\n\t\t\tCvSource outputStream = CameraServer.getInstance().putVideo(\"Camera1\", 640, 480); \n\t\t\t//set up a new camera with this name in SmartDashboard (Veiw->Add->CameraServer Stream Viewer)\n\t\t\t\n\t\t\tMat source = new Mat();\n\t\t\tMat output = new Mat();\n\t\t\t\n\t\t\twhile(!Thread.interrupted())\n\t\t\t{\n\t\t\t\tcvSink.grabFrame(source);\n\t\t\t\tImgproc.cvtColor(source, output, Imgproc.COLOR_BGR2RGB);//this will show the video in black and white \n\t\t\t\toutputStream.putFrame(output);\n\t\t\t}\t\t\t\t\t\n\t\t}).start();//definition of camera, runs even when disabled\n\t\t\n\t\tdriveStick = new Joystick(0); //further definition of joystick\n\t\tgyroRotate.gyroInit(); //initializing the gyro - in Rotate_Subsystem\n\t\tultrasonic = new Ultrasonic_Sensor(); //further definition of ultrasonic\n\t\tRobotMap.encoderLeft.reset();\n\t\tRobotMap.encoderRight.reset();\n\t\tdriveToDistance.controllerInit();\n\t}", "@Override\n public void runOpMode() {\n try {\n leftfrontDrive = hardwareMap.get(DcMotor.class, \"frontLeft\");\n leftfrontDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n rightfrontDrive = hardwareMap.get(DcMotor.class, \"frontRight\");\n rightfrontDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n leftbackDrive = hardwareMap.get(DcMotor.class, \"backLeft\");\n leftbackDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n leftbackDrive.setDirection(DcMotor.Direction.REVERSE);\n\n rightbackDrive = hardwareMap.get(DcMotor.class, \"backRight\");\n rightbackDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n lift = hardwareMap.get(DcMotor.class, \"Lift\");\n lift.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n lift.setDirection(DcMotor.Direction.REVERSE);\n\n markerArm = hardwareMap.get(Servo.class, \"markerArm\");\n\n armActivator = hardwareMap.get(DcMotor.class, \"armActivator\");\n armActivator.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n } catch (IllegalArgumentException iax) {\n bDebug = true;\n }\n\n BNO055IMU.Parameters parameters = new BNO055IMU.Parameters();\n parameters.angleUnit = BNO055IMU.AngleUnit.DEGREES;\n parameters.accelUnit = BNO055IMU.AccelUnit.METERS_PERSEC_PERSEC;\n parameters.calibrationDataFile = \"BNO055IMUCalibration.json\";\n parameters.loggingEnabled = true;\n parameters.loggingTag = \"IMU\";\n parameters.accelerationIntegrationAlgorithm = new JustLoggingAccelerationIntegrator();\n\n imu = hardwareMap.get(BNO055IMU.class, \"imu\");\n imu.initialize(parameters);\n\n waitForStart(); //the rest of the code begins after the play button is pressed\n\n sleep(3000);\n\n drive(0.35, 0.5);\n\n turn(90.0f);\n\n drive(1.8, 0.5);\n\n turn(45.0f);\n\n drive(2.5, -0.5);\n\n sleep(1000);\n\n markerArm.setPosition(1);\n\n sleep(1000);\n\n markerArm.setPosition(0);\n\n sleep(1000);\n\n drive(2.5,.75);\n\n turn(179.0f);\n\n drive(1.5, 1.0);\n\n requestOpModeStop(); //end of autonomous\n }", "@Override\n public void runOpMode() throws InterruptedException {\n super.runOpMode();\n // LeftServo.setPosition(0.4);\n // RightServo.setPosition(0.5);\n\n waitForStart();\n telemetry.addData(\"Angles\", MyDriveTrain.getAngle());\n telemetry.update();\n telemetry.addData(\"Mikum:\", Mikum);\n telemetry.update();\n LF.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.FLOAT);\n RF.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.FLOAT);\n LB.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.FLOAT);\n RB.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.FLOAT);\n\n MyDriveTrain.encoderDrive(0.8, -30, 30, 30, -30, 1);\n MyDriveTrain.Rotate(0,0.1,10);\n// Mikum = MyVuforiaStone.ConceptVuforiaSkyStoneNavigationWebcam();\n// Mikum = 3;\n LF.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n RF.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n LB.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n RB.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n\n if (Mikum > 2) {\n telemetry.addLine(\"you're on the right\");\n telemetry.update();\n MyDriveTrain.encoderDrive(0.8, -84, 84, 84, -84, 1);\n MyIntake.maxIntake();\n MyDriveTrain.encoderDrive(0.8, -25, -25, -25, -25, 2);\n sleep(500);\n// MyDriveTrain.Verification(cubeIn,cubeNotInMM);\n\n MyIntake.ShutDown();\n MyDriveTrain.encoderDrive(0.8, 45, -45, -45, 45, 1);\n MyDriveTrain.Rotate(0,0.1,10);\n MyDriveTrain.encoderDrive(0.8, 100, 100, 100, 100, 2);\n }\n\n else if (Mikum < -2) {\n telemetry.addLine(\"you're on the left\");\n telemetry.update();\n MyDriveTrain.encoderDrive(0.8, 15, 15, 15, 15, 2);\n MyDriveTrain.encoderDrive(0.8, -86, 86, 86, -86, 1);\n MyIntake.maxIntake();\n MyDriveTrain.encoderDrive(0.8, -25, -25, -25, -25, 2);\n sleep(500);\n// MyDriveTrain.Verification(cubeIn,cubeNotInMM);\n\n MyIntake.ShutDown();\n MyDriveTrain.encoderDrive(0.8, 50, -50, -50, 50, 1);\n MyDriveTrain.Rotate(0,0.1,10);\n MyDriveTrain.encoderDrive(1, 85, 85, 85, 85, 2);\n\n\n\n } else {\n telemetry.addLine(\"You are on the center!\");\n telemetry.update();\n MyDriveTrain.encoderDrive(0.8, 30, 30, 30, 30, 2);\n MyDriveTrain.encoderDrive(0.5, -82, 82, 82, -82, 1);\n MyIntake.maxIntake();\n MyDriveTrain.encoderDrive(0.8, -25, -25, -25, -25, 2);\n sleep(500);\n// MyDriveTrain.Verification(cubeIn,cubeNotInMM);\n\n MyIntake.ShutDown();\n MyDriveTrain.encoderDrive(0.8, 45, -45, -45, 45, 1);\n MyDriveTrain.Rotate(0,0.1,10);\n MyDriveTrain.encoderDrive(1, 80, 80, 80, 80, 2);\n\n }\n\n MyDriveTrain.Rotate(0,0.2,10);\n MyIntake.maxIntake();\n sleep(500);\n MyIntake.ShutDown();\n Output.setPosition(OutputDown);\n MyDriveTrain.encoderDrive(1, 130, 130, 130, 130, 2);\n MyDriveTrain.encoderDrive(0.8, -5, 5, 5, -5, 1);\n\n MyDriveTrain.RotateP(90,1,10,0.0108);\n sleep(500);\n MyDriveTrain.encoderDrive(0.2,29,29,29,29,2);\n MyDriveTrain.Rotate(90,0.1,10);\n LeftServo.setPosition(0.15);\n RightServo.setPosition(0.2);\n MyDriveTrain.encoderDrive(0.1,10,10,10,10,2);\n LeftServo.setPosition(LeftServoDown);\n RightServo.setPosition(RightServoDown);\n sleep(500);\n MyDriveTrain.encoderDrive(1,-90,-90,-90,-90,2);\n MyDriveTrain.Rotate(-0,0.5,10);\n MyDriveTrain.encoderDrive(1,40,40,40,40,2);\n\n MyElevator.ElevateWithEncoder(-450, 0.8, 0.5);\n sleep(500);\n Arm.setPosition(1);\n sleep(1500);\n MyElevator.ElevateWithEncoder(0, 0.3, 0.0035);\n sleep(700);\n Output.setPosition(OutputUp);\n sleep(500);\n MyElevator.ElevateWithEncoder(-500, 0.3, 0.5);\n Arm.setPosition(0.135);\n sleep(1000);\n MyElevator.ElevateWithEncoder(0, 0.5, 0.003);\n\n LeftServo.setPosition(LeftServoUp);\n RightServo.setPosition(RightServoUp);\n MyDriveTrain.Rotate(0,0.4,10);\n MyDriveTrain.encoderDrive(0.3,-30,30,30,-30,2);\n ParkingMot.setPosition(ParkingMotIn);\n sleep(500);\n MyDriveTrain.encoderDrive(0.8, -5, 5, 5, -5, 1);\n MyDriveTrain.encoderDrive(0.5,-43,-43, -43,-43,1);\n }", "public void resetGyroAngle() {\n\t\tgyro.reset();\n\t}", "public void onSensorChanged(SensorEvent event) {\n\t\t\tint type = event.sensor.getType();\n\t\t\tif (type == Sensor.TYPE_ACCELEROMETER) {\n\t\t\t\tlong curTime = System.currentTimeMillis();\n\t\t\t\t// only allow one update every 100ms, otherwise updates\n\t\t\t\t// come way too fast and the phone gets bogged down\n\t\t\t\t// with garbage collection\n\t\t\t\t//Log.d(TAG, \"onSensorChanged(\"+type+\")\");\t\t\t\t\n\t\t\t\tif (lastUpdate == -1 || (curTime - lastUpdate) > 40) {\n\t\t\t\t\tlastUpdate = curTime;\t\t\t\t\n\t\t\t\t\tsynchronized (LOCK){\n\t\t\t\t\t\tmLastAccOrientation = calculateAngle(event);\n\t\t\t\t\t\tmLastSample.x = event.values[0];\n\t\t\t\t\t\tmLastSample.y = event.values[1];\n\t\t\t\t\t\tmLastSample.z = event.values[2];\n\t\t\t\t\t\tmLastSample.angle = mLastAccOrientation.angle;\t\t\n\t\t\t\t\t\t//mLastSample.orientation = mLastAccOrientation.orientation;\n\t\t\t\t\t\tmLastSample.orientation = mLastAccOrientation.rotation*90;\n\t\t\t\t\t\tmLastSample.threshold = mLastAccOrientation.threshold;\n\t\t\t\t\t\tmBuffer = mLastSample.x+\",\"+\n\t\t\t\t\t\t\t\t mLastSample.y+\",\"+\n\t\t\t\t\t\t\t\t mLastSample.z+\",\"+\n\t\t\t\t\t\t\t\t mLastSample.angle+\",\"+\n\t\t\t\t\t\t\t\t mLastSample.orientation+\",\"+\n\t\t\t\t\t\t\t\t mLastSample.threshold;\n\t\t\t\t\t\tif (mShowLog)\n\t\t\t\t\t\t\tLog.d(TAG, mBuffer);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}", "private void initSensorManager() {\n\t\ttry {\n\t\t\tSensorManager sensorManage = (SensorManager) getSystemService(Context.SENSOR_SERVICE);\n\t\t\tList<Sensor> mySensors = sensorManage\n\t\t\t\t\t.getSensorList(Sensor.TYPE_ACCELEROMETER);\n\t\t\tmAccel = 0.00f;\n\t\t\tmAccelCurrent = SensorManager.GRAVITY_EARTH;\n\t\t\tmAccelLast = SensorManager.GRAVITY_EARTH;\n\t\t\tsensorManage.registerListener(new SensorEventListener() {\n\t\t\t\tpublic void onAccuracyChanged(Sensor sensor, int accuracy) {\n\n\t\t\t\t}\n\n\t\t\t\t@SuppressLint(\"FloatMath\")\n\t\t\t\tpublic void onSensorChanged(SensorEvent event) {\n\n\t\t\t\t\tfloat x = event.values[0];// Get X-Coordinator\n\n\t\t\t\t\tfloat y = event.values[1];// Get Y-Coordinator\n\n\t\t\t\t\tfloat z = event.values[2];// Get Z-Coordinator\n\n\t\t\t\t\tmAccelLast = mAccelCurrent;\n\t\t\t\t\tmAccelCurrent = (float) Math\n\t\t\t\t\t\t\t.sqrt((double) (x * x + y * y + z * z));\n\t\t\t\t\tfloat delta = mAccelCurrent - mAccelLast;\n\t\t\t\t\tmAccel = mAccel * 0.9f + delta; // perform low-cut filter\n\n\t\t\t\t\tif (SHAKING_DELTA > mAccel\n\t\t\t\t\t\t\t&& CommonValues.getInstance().CameraMessage != CameraMessageStatus.Focused) {\n\t\t\t\t\t\t// BY SAM for start autofocusing\n\t\t\t\t\t\tif (!lock_autofocus) {\n\t\t\t\t\t\t\tif (autoFocusCounter > AUTO_FOCUS_START_INTERVAL\n\t\t\t\t\t\t\t\t\t&& CommonValues.getInstance().CameraMessage == CameraMessageStatus.Shacked) {\n//\t\t\t\t\t\t\t\tCameraManager.get().requestAutoFocus(handler,\n//\t\t\t\t\t\t\t\t\t\tR.id.auto_focus);\n\t\t\t\t\t\t\t\tautoFocusCounter = 0;\n\t\t\t\t\t\t\t\tCommonValues.getInstance().CameraMessage = CameraMessageStatus.Stopped;\n\t\t\t\t\t\t\t} else if (autoFocusCounter > AUTO_FOCUS_START_INTERVAL) {\n\t\t\t\t\t\t\t\tautoFocusCounter = 0;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\tif (!lock_autofocus\n\t\t\t\t\t\t\t\t&& Math.abs(z - old_z) > SHAKING_Z_DELTA) {\n\n\t\t\t\t\t\t\tstatusView.setText(getString(R.string.set_focus));\n//\t\t\t\t\t\t\tCameraManager.get().requestAutoFocus(handler,\n//\t\t\t\t\t\t\t\t\tR.id.auto_focus);\n\t\t\t\t\t\t\tautoFocusCounter = 0;\n\n\t\t\t\t\t\t} else {\n\t\t\t\t\t\t\tif (!lock_autofocus) {\n\n\t\t\t\t\t\t\t\tstatusView\n\t\t\t\t\t\t\t\t\t\t.setText(getString(R.string.brcd_img_middle));\n\t\t\t\t\t\t\t\tautoFocusCounter++;\n\t\t\t\t\t\t\t} else {\n\n\t\t\t\t\t\t\t\tstatusView\n\t\t\t\t\t\t\t\t\t\t.setText(getString(R.string.brcd_press_focus));\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\n\t\t\t\t\t} else if (mAccel > SHAKING_DELTA)// Shaking\n\t\t\t\t\t{\n\n\t\t\t\t\t\tstatusView.setText(getString(R.string.phone_silent));\n\t\t\t\t\t\tCommonValues.getInstance().CameraMessage = CameraMessageStatus.Shacked;\n\n\t\t\t\t\t} else {\n\n\t\t\t\t\t\tstatusView.setText(getString(R.string.set_focus));\n\t\t\t\t\t\tCommonValues.getInstance().CameraMessage = CameraMessageStatus.Stopped;\n\n\t\t\t\t\t}\n\t\t\t\t\told_z = z;\n\n\t\t\t\t}\n\t\t\t}, mySensors.get(0), SensorManager.SENSOR_DELAY_NORMAL);\n\n\t\t} catch (Exception e) {\n\t\t\tLog.e(\"Unable to detect SensorManager. \",\n\t\t\t\t\t\"Error data \" + e.toString());\n\t\t}\n\t}", "@Override\n public void robotInit() {\n\n // Motor controllers\n leftMotor = new CANSparkMax(1, MotorType.kBrushless);\n leftMotor.setInverted(false);\n leftMotor.setIdleMode(IdleMode.kBrake);\n\n CANSparkMax leftSlave1 = new CANSparkMax(2, MotorType.kBrushless);\n leftSlave1.setInverted(false);\n leftSlave1.setIdleMode(IdleMode.kBrake);\n leftSlave1.follow(leftMotor);\n\n CANSparkMax leftSlave2 = new CANSparkMax(3, MotorType.kBrushless);\n leftSlave2.setInverted(false);\n leftSlave2.setIdleMode(IdleMode.kBrake);\n leftSlave2.follow(leftMotor);\n\n rightMotor = new CANSparkMax(4, MotorType.kBrushless);\n rightMotor.setInverted(false);\n rightMotor.setIdleMode(IdleMode.kBrake);\n\n CANSparkMax rightSlave1 = new CANSparkMax(5, MotorType.kBrushless);\n rightSlave1.setInverted(false);\n rightSlave1.setIdleMode(IdleMode.kBrake);\n rightSlave1.follow(leftMotor);\n\n CANSparkMax rightSlave2 = new CANSparkMax(6, MotorType.kBrushless);\n rightSlave2.setInverted(false);\n rightSlave2.setIdleMode(IdleMode.kBrake);\n rightSlave2.follow(leftMotor);\n\n // Encoders\n leftEncoder = leftMotor.getEncoder();\n rightEncoder = rightMotor.getEncoder();\n\n // Gyro\n gyro = new ADXRS450_Gyro();\n\n }", "public void gyroDrive ( double speed,\n double distance,\n double angle) {\n\n int newLeftTarget;\n int newRightTarget;\n int moveCounts;\n double max;\n double error;\n double steer;\n double leftSpeed;\n double rightSpeed;\n\n // Ensure that the opmode is still active\n if (opModeIsActive()) {\n\n // Determine new target position, and pass to motor controller\n moveCounts = (int)(distance * COUNTS_PER_INCH);\n newLeftTarget = leftMotor.getCurrentPosition() + moveCounts;\n newRightTarget = rightMotor.getCurrentPosition() + moveCounts;\n\n // Set Target and Turn On RUN_TO_POSITION\n leftMotor.setTargetPosition(newLeftTarget);\n rightMotor.setTargetPosition(newRightTarget);\n\n leftMotor.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n rightMotor.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n\n // start motion.\n speed = Range.clip(Math.abs(speed), 0.0, 1.0);\n leftMotor.setPower(speed);\n rightMotor.setPower(speed);\n\n // keep looping while we are still active, and BOTH motors are running.\n while (opModeIsActive() &&\n (leftMotor.isBusy() && rightMotor.isBusy())) {\n\n // adjust relative speed based on heading error.\n error = getError(angle);\n steer = getSteer(error, P_DRIVE_COEFF);\n\n // if driving in reverse, the motor correction also needs to be reversed\n if (distance < 0)\n steer *= -1.0;\n\n leftSpeed = speed - steer;\n rightSpeed = speed + steer;\n\n // Normalize speeds if any one exceeds +/- 1.0;\n max = Math.max(Math.abs(leftSpeed), Math.abs(rightSpeed));\n if (max > 1.0)\n {\n leftSpeed /= max;\n rightSpeed /= max;\n }\n\n leftMotor.setPower(leftSpeed);\n rightMotor.setPower(rightSpeed);\n\n // Display drive status for the driver.\n telemetry.addData(\"Err/St\", \"%5.1f/%5.1f\", error, steer);\n telemetry.addData(\"Target\", \"%7d:%7d\", newLeftTarget, newRightTarget);\n telemetry.addData(\"Actual\", \"%7d:%7d\", leftMotor.getCurrentPosition(),\n rightMotor.getCurrentPosition());\n telemetry.addData(\"Speed\", \"%5.2f:%5.2f\", leftSpeed, rightSpeed);\n telemetry.update();\n }\n\n // Stop all motion;\n\n rightMotor.setPower(0);\n leftMotor.setPower(0);\n\n // Turn off RUN_TO_POSITION\n leftMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n rightMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n }\n }", "protected void initialize() {\n if ( Math.abs( m_autorotateangle - Robot.drive.gyroGetAngle()) <= 45) {\n rampthreshold = 35;\n } else { // > 45 degrees}\n rampthreshold = Math.abs( m_autorotateangle - Robot.drive.gyroGetAngle()) / 2.5;\n }\n\n \tsetTimeout(m_timeout);\n\n }", "public void gyroTurn(double speed, double angle) {\n while (opModeIsActive() && !onHeading(speed, angle, P_TURN_COEFF)) {\n // Update telemetry & Allow time for other processes to run.\n telemetry.update();\n }\n }", "public void commonPeriodic()\n {\n double d1LeftJoystick = driver1.getAxis(driver1.LAxisUD);\n double d1RightJoystick = driver1.getAxis(driver1.RAxisUD);\n\n double d2LeftJoystick = driver2.getAxis(driver2.LAxisUD);\n double d2RightJoystick = driver2.getAxis(driver2.RAxisUD);\n\n // -------------------- DRIVER 1\n\n driveTrain.drive(d1LeftJoystick * speedModifier, d1RightJoystick * speedModifier);\n\n // driver1 controls ramp\n // press start and select together to deploy\n if(driver1.down(driver1.Start) && driver1.down(driver1.Select))\n {\n ramp.deploy();\n hatchArm.fingerGrab();\n }\n else\n {\n ramp.undeploy();\n }\n\n // driver 1 can double speed by holding L2\n //driveTrain.fastSpeed = driver1.down(driver1.L2);\n if(driver1.pressed(driver1.A))\n {\n driveTrain.slowSpeed = !driveTrain.slowSpeed;\n System.out.println(\"Fast speed toggled to: \" + driveTrain.slowSpeed);\n }\n\n //drive straight\n if(driver1.down(driver1.L1))\n {\n driveTrain.set_right_motors(speedModifier);\n }\n if(driver1.down(driver1.R1))\n {\n driveTrain.set_left_motors(speedModifier);\n }\n\n // flip drive orientation\n if(driver1.pressed(driver1.Select))\n {\n driveTrain.flip_orientation();\n \n if(driveTrain.isFacingForward())\n {\n camServForward.setSource(camFront);\n //camServReverse.setSource(camBack);\n // camBack.free();\n // camFront.close();\n // camFront = CameraServer.getInstance().startAutomaticCapture(0);\n // camBack = CameraServer.getInstance().startAutomaticCapture(1);\n }\n else\n {\n camServForward.setSource(camBack);\n //camServReverse.setSource(camFront);\n // camBack.close();\n // camFront.close();\n // camFront = CameraServer.getInstance().startAutomaticCapture(1);\n // camBack = CameraServer.getInstance().startAutomaticCapture(0);\n }\n }\n\n\n // -------------------- DRIVER 2\n\n\n // up is out\n // down is in\n // (when it's negated)\n cargoArm.spinBallMotor(-1 * d2LeftJoystick * 0.9);\n\n // control hatch placement pistons\n if(driver2.pressed(driver2.A))\n {\n hatchArm.pushPistons();\n }\n else if (driver2.released(driver2.A))\n {\n hatchArm.retractPistons();\n }\n\n // open/close hatch grabber arms\n if(driver2.pressed(driver2.B))\n {\n hatchArm.toggleGrabber();\n }\n\n if(driver2.pressed(driver2.Select))\n {\n //cargoArm.toggleArmLock();\n hatchArm.toggleFinger();\n }\n\n // extend/de-extend cargo hand\n if(driver2.pressed(driver2.Start))\n {\n cargoArm.toggleHand();\n }\n\n // button 7: L2\n // button 8: R2\n // L2 will reverse the finger\n // R2 will rotate it forward\n if(driver2.down(driver2.L1))\n {\n hatchArm.rotateFinger(1);\n }\n else\n {\n if(driver2.down(driver2.L2))\n {\n hatchArm.rotateFinger(-1);\n }\n else\n {\n hatchArm.rotateFinger(0);\n }\n }\n\n \n // button 5: L1\n // button 6: R1\n // L1 will move the hatch arm one way\n // R1 will move it the other way\n if(driver2.down(driver2.R1))\n {\n hatchArm.rotateArm(-1 * speedModifier);// * 0.75);\n }\n else\n {\n if(driver2.down(driver2.R2))\n {\n hatchArm.rotateArm(1 * speedModifier);// * 0.75);\n }\n else\n {\n hatchArm.rotateArm(0);\n }\n }\n\n \n // button 1: x\n // button 4: y\n // button 1 will move the ball arm one way\n // button 4 will move it the other way\n if(driver2.down(driver2.X))\n {\n //cargoArm.requestMove(-1 * speedModifier);\n cargoArm.rotateArm(-1);\n //cargoArm.solArmBrake.set(false);\n }\n else\n {\n if(driver2.down(driver2.Y))\n {\n //cargoArm.requestMove(2 * speedModifier);\n cargoArm.rotateArm(1);\n //cargoArm.solArmBrake.set(false);\n }\n else\n {\n //cargoArm.rotateArm(cargoArm.getArmCalculation());\n //cargoArm.solArmBrake.set(true);\n cargoArm.rotateArm(0);\n }\n }\n if(driver2.released(driver2.X) || driver2.released(driver2.Y))\n {\n //cargoArm.setArmTarget(cargoArm.currentPosition());\n //cargoArm.solArmBrake.set(true);\n cargoArm.rotateArm(0);\n }\n\n if(driver2.dpad(driver2.Up))\n {\n cargoArm.setArmUp();\n }\n if(driver2.dpad(driver2.Down))\n {\n cargoArm.setArmDown();\n }\n if(driver2.dpad(driver2.Left))\n {\n cargoArm.setArmMid();\n }\n if(driver2.dpad(driver2.Right))\n {\n cargoArm.setArmLow();\n }\n\n if(driver2.pressed(driver2.LThumb))\n {\n cargoArm.armLockEnabled = !cargoArm.armLockEnabled;\n \n }\n if(driver2.pressed(driver2.RThumb))\n {\n cargoArm.toggleBrake();\n }\n\n\n // allow move-to calculations to occur\n hatchArm.periodic();\n cargoArm.periodic();\n }", "public void runOpMode() throws InterruptedException {\n leftWheel = hardwareMap.dcMotor.get(\"leftWheel\");\n rightWheel = hardwareMap.dcMotor.get(\"rightWheel\");\n leftArm = hardwareMap.dcMotor.get(\"leftArm\");\n rightArm = hardwareMap.dcMotor.get(\"rightArm\");\n rightDistance = hardwareMap.get(DistanceSensor.class, \"rightDistance\");\n leftColor = hardwareMap.colorSensor.get(\"leftColor\");\n rightWheel.setDirection(DcMotorSimple.Direction.REVERSE);\n count = 21;\n step = 3;\n subStep = 0;\n\n sample_ready = false;\n lander_unlatched = false;\n\n //prepares and resets robot by resetting encoders\n resetDriveEncoders();\n\n //prepares robot for arm movement by setting arm motors to go to a certain position-modifiable by user input (the d-pad)\n// leftArm.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n// rightArm.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n\n //HSV value array\n\n //Sends color sensor input values to the phone\n waitForStart();\n\n while (opModeIsActive()) {\n telemetry.update();\n\n\n telemetry.addLine()\n .addData(\"step\", step)\n .addData(\"subStep\", subStep)\n .addData(\"count\", count);\n telemetry.addLine()\n .addData(\"RightWheel: \", rightWheel.getCurrentPosition())\n .addData(\"LeftWheel: \", leftWheel.getCurrentPosition())\n .addData(\"TICKS_PER_WHEEL_ROTATION: \", TICKS_PER_WHEEL_ROTATION);\n\n\n//sets the step of where we are in the process to one\n // step = 1;\n//enables the if statement for lander_unlatched\n lander_unlatched = true;\n//moves the robot from the lander to where the samples are\n if (step == 1) {\n// leftWheel.setPower(0.7);\n// rightWheel.setPower(0.5);\n// leftWheel.setTargetPosition(1621);\n// rightWheel.setTargetPosition(820);\n step = 2;\n }\n if (step == 2) {\n// if (hsvValues[0] > 50) {\n// leftWheel.setPower(-0.7);\n// rightWheel.setPower(-0.5);\n// leftWheel.setTargetPosition(1221);\n step = 3;\n }\n// if step 2 is finished, makes the robot turn toward the wall, then drives against the wall.\n if (step == 3) {\n moveToDepot();\n }\n //1150 Target Units == about 1 foot, 96 Units/inch\n//sets the wheel power to 0 to limit movement\n// if (rightWheel.getCurrentPosition() == -rotation) {\n // rightWheel.setPower(0);\n //leftWheel.setPower(0);\n// }\n// if (leftWheel.getCurrentPosition() == 100) {\n// leftWheel.setPower(0);\n// rightWheel.setPower(0);\n// }\n\n sample_ready = true;\n\n// if (sample_ready) {\n//\n }\n }", "public final void GyroTurn (int degrees, double power)\n {\n //Define gyro angle\n float GyroAngle = robot.Gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle;\n\n //While the gyro is reading degrees that is not the desired, turn right or left\n while (GyroAngle != degrees)\n {\n //\n robot.DriveLeftBack.setPower(-.1);\n robot.DriveRightBack.setPower(.1);\n robot.DriveRightFront.setPower(.1);\n robot.DriveLeftFront.setPower(-.1);\n\n //Update gyro angle\n GyroAngle = robot.Gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle;\n }\n\n //Stop\n Stop();\n }", "public double getGyroInDeg(){\n return 0.0;//TODO:Pull gyro in radians and convert to degrees\n }", "public SoilMoistureSensor() {\r\n\t\tthis.cancel = false;\r\n\t\tthis.soilMoisture = 0;\r\n\t\tthis.updateInterval = 90; //Sensor update interval is 90 seconds.\r\n\t}", "public void gyroHold( double speed, double angle, double holdTime) {\n\n ElapsedTime holdTimer = new ElapsedTime();\n\n // keep looping while we have time remaining.\n holdTimer.reset();\n while (opModeIsActive() && (holdTimer.time() < holdTime)) {\n // Update telemetry & Allow time for other processes to run.\n onHeading(speed, angle, P_TURN_COEFF);\n telemetry.update();\n }\n\n // Stop all motion;\n robot.leftDrive.setPower(0);\n robot.rightDrive.setPower(0);\n }", "protected void initialize() {\n \t starttime = Timer.getFPGATimestamp();\n \tthis.startAngle = RobotMap.navx.getAngle();\n \tangleorientation.setSetPoint(RobotMap.navx.getAngle());\n \t\n \tRobotMap.motorLeftTwo.enableControl();\n \tRobotMap.motorRightTwo.enableControl();\n \tRobotMap.motorLeftTwo.enableControl();\n \tRobotMap.motorRightTwo.enableControl();\n \n //settting talon control mode\n \tRobotMap.motorLeftTwo.changeControlMode(TalonControlMode.MotionMagic);\t\t\n\t\tRobotMap.motorLeftOne.changeControlMode(TalonControlMode.Follower);\t\n\t\tRobotMap.motorRightTwo.changeControlMode(TalonControlMode.MotionMagic);\t\n\t\tRobotMap.motorRightOne.changeControlMode(TalonControlMode.Follower);\n\t\t//setting peak and nominal output voltage for the motors\n\t\tRobotMap.motorLeftTwo.configPeakOutputVoltage(+12.0f, -12.0f);\n\t\tRobotMap.motorLeftTwo.configNominalOutputVoltage(0.00f, 0.0f);\n\t\tRobotMap.motorRightTwo.configPeakOutputVoltage(+12.0f, -12.0f);\n\t\tRobotMap.motorRightTwo.configNominalOutputVoltage(0.0f, 0.0f);\n\t\t//setting who is following whom\n\t\tRobotMap.motorLeftOne.set(4);\n\t\tRobotMap.motorRightOne.set(3);\n\t\t//setting pid value for both sides\n\t//\tRobotMap.motorLeftTwo.setCloseLoopRampRate(1);\n\t\tRobotMap.motorLeftTwo.setProfile(0);\n\t RobotMap.motorLeftTwo.setP(0.000014f);\n \tRobotMap.motorLeftTwo.setI(0.00000001);\n\t\tRobotMap.motorLeftTwo.setIZone(0);//325);\n\t\tRobotMap.motorLeftTwo.setD(1.0f);\n\t\tRobotMap.motorLeftTwo.setF(this.fGainLeft+0.014);//0.3625884);\n\t\tRobotMap.motorLeftTwo.setAllowableClosedLoopErr(0);//300);\n\t\t\n\t RobotMap.motorRightTwo.setCloseLoopRampRate(1);\n\t RobotMap.motorRightTwo.setProfile(0);\n\t\tRobotMap.motorRightTwo.setP(0.000014f);\n\t\tRobotMap.motorRightTwo.setI(0.00000001);\n\t\tRobotMap.motorRightTwo.setIZone(0);//325);\n\t\tRobotMap.motorRightTwo.setD(1.0f);\n\t\tRobotMap.motorRightTwo.setF(this.fGainRight);// 0.3373206);\n\t\tRobotMap.motorRightTwo.setAllowableClosedLoopErr(0);//300);\n\t\t\n\t\t//setting Acceleration and velocity for the left\n\t\tRobotMap.motorLeftTwo.setMotionMagicAcceleration(125);\n\t\tRobotMap.motorLeftTwo.setMotionMagicCruiseVelocity(250);\n\t\t//setting Acceleration and velocity for the right\n\t\tRobotMap.motorRightTwo.setMotionMagicAcceleration(125);\n\t\tRobotMap.motorRightTwo.setMotionMagicCruiseVelocity(250);\n\t\t//resets encoder position to 0\t\t\n\t\tRobotMap.motorLeftTwo.setEncPosition(0);\n\t\tRobotMap.motorRightTwo.setEncPosition(0);\n\t //Set Allowable error for the loop\n\t\tRobotMap.motorLeftTwo.setAllowableClosedLoopErr(300);\n\t\tRobotMap.motorRightTwo.setAllowableClosedLoopErr(300);\n\t\t\n\t\t//sets desired endpoint for the motors\n RobotMap.motorLeftTwo.set(motionMagicEndPoint);\n RobotMap.motorRightTwo.set(-motionMagicEndPoint );\n \t\n }", "public void gyroDrive ( double speed,\n double distance,\n double angle) {\n\n int newLeftTarget;\n int newRightTarget;\n int moveCounts;\n double max;\n double error;\n double steer;\n double leftSpeed;\n double rightSpeed;\n\n // Ensure that the opmode is still active\n if (opModeIsActive()) {\n\n // Determine new target position, and pass to motor controller\n moveCounts = (int)(distance * COUNTS_PER_INCH);\n newLeftTarget = robot.leftDrive.getCurrentPosition() + moveCounts;\n newRightTarget = robot.rightDrive.getCurrentPosition() + moveCounts;\n\n // Set Target and Turn On RUN_TO_POSITION\n robot.leftDrive.setTargetPosition(newLeftTarget);\n robot.rightDrive.setTargetPosition(newRightTarget);\n\n robot.leftDrive.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n robot.rightDrive.setMode(DcMotor.RunMode.RUN_TO_POSITION);\n\n // start motion.\n speed = Range.clip(Math.abs(speed), 0.0, 1.0);\n robot.leftDrive.setPower(speed);\n robot.rightDrive.setPower(speed);\n\n // keep looping while we are still active, and BOTH motors are running.\n while (opModeIsActive() &&\n (robot.leftDrive.isBusy() && robot.rightDrive.isBusy())) {\n\n // adjust relative speed based on heading error.\n error = getError(angle);\n steer = getSteer(error, P_DRIVE_COEFF);\n\n // if driving in reverse, the motor correction also needs to be reversed\n if (distance < 0)\n steer *= -1.0;\n\n leftSpeed = speed - steer;\n rightSpeed = speed + steer;\n\n // Normalize speeds if either one exceeds +/- 1.0;\n max = Math.max(Math.abs(leftSpeed), Math.abs(rightSpeed));\n if (max > 1.0)\n {\n leftSpeed /= max;\n rightSpeed /= max;\n }\n\n robot.leftDrive.setPower(leftSpeed);\n robot.rightDrive.setPower(rightSpeed);\n\n // Display drive status for the driver.\n telemetry.addData(\"Err/St\", \"%5.1f/%5.1f\", error, steer);\n telemetry.addData(\"Target\", \"%7d:%7d\", newLeftTarget, newRightTarget);\n telemetry.addData(\"Actual\", \"%7d:%7d\", robot.leftDrive.getCurrentPosition(),\n robot.rightDrive.getCurrentPosition());\n telemetry.addData(\"Speed\", \"%5.2f:%5.2f\", leftSpeed, rightSpeed);\n telemetry.update();\n }\n\n // Stop all motion;\n robot.leftDrive.setPower(0);\n robot.rightDrive.setPower(0);\n\n // Turn off RUN_TO_POSITION\n robot.leftDrive.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n robot.rightDrive.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\n }\n }", "@Override\r\n\tpublic String getSmartDashboardType() {\r\n\t\treturn \"Gyro\";\r\n\t}", "@Override\n public final void onSensorChanged(SensorEvent event) {\n linearAccelerations = event.values;\n linearAccelerations[0] = linearAccelerations[0]-xOff;\n linearAccelerations[1] = linearAccelerations[1]-yOff;\n linearAccelerations[2] = linearAccelerations[2]-zOff;\n xAccel = (float) round(linearAccelerations[0]/9.8, 3);\n yAccel = (float) round(linearAccelerations[1]/9.8, 3);\n zAccel = (float) round(linearAccelerations[2]/9.8, 3);\n// Log.i(appLabel, \"Acceleration: (\"+xAccel+\", \"+yAccel+\", \"+zAccel+\")\");\n xAccelSquared = (float) round(xAccel*xAccel, 3);\n yAccelSquared = (float) round(yAccel*yAccel, 3);\n zAccelSquared = (float) round(zAccel*zAccel, 3);\n //If they are negative accelerations, squaring them will have made them positive\n if (xAccel < 0) {\n xAccelSquared = xAccelSquared*-1;\n }\n if (yAccel < 0) {\n yAccelSquared = yAccelSquared*-1;\n }\n if (zAccel < 0) {\n zAccelSquared = zAccelSquared*-1;\n }\n xAccelOutput.setText(String.valueOf(xAccel));\n yAccelOutput.setText(String.valueOf(yAccel));\n zAccelOutput.setText(String.valueOf(zAccel));\n// Log.i(appLabel, \"Acceleration squares: \"+xAccelSquared+\", \"+yAccelSquared+\", \"+zAccelSquared);\n float accelsSum = xAccelSquared+yAccelSquared+zAccelSquared;\n double accelsRoot;\n if (accelsSum < 0) {\n accelsSum = accelsSum * -1;\n accelsRoot = Math.sqrt(accelsSum) * -1;\n } else {\n accelsRoot = Math.sqrt(accelsSum);\n }\n// Log.i(appLabel, \"Acceleration squares sum: \"+accelsSum);\n// Log.i(appLabel, \"Acceleration sqrt:\"+accelsRoot);\n cAccel = (float) round(accelsRoot, 3);\n// Log.i(appLabel, \"Net Acceleration: \"+cAccel);\n //Store the maximum acceleration\n if (cAccel > maxAccel) {\n maxAccel = cAccel;\n }\n accelOutput.setText(String.valueOf(cAccel));\n if (isRunning) {\n setSpeed();\n }\n if (speed >= 60) {\n timeToSixty = seconds;\n timeToSixtyOutput.setText(String.valueOf(timeToSixty));\n stopTimer();\n }\n }", "public void teleopContinuous() {\n //feed the watchdog\n myDog.feed();\n\n //check safestop button\n /*safestop commented out\n if (joysticks.getRightButton(10))//Buttons on top of right stick stops robot\n {\n safeStop();\n //delay to allow driver to release button\n Timer.delay(.1);\n myDog.feed();\n //at this point driver should have released the butto\n while (!joysticks.getRightTop()) {\n myDog.feed();\n }\n //now the button is pressed again, indicating a restart- the program can continue\n\n //slight delay to allow driver to release the button before the next loop\n Timer.delay(.1);\n }\n */\n\n //if arm is in teleop mode, handles input accordingly\n if (armState == TELEOP) {\n handleArmInput();\n }\n\n //if arm is in auto mode, checks whether user is pressing button 1 to regain\n //control and stops the auto task if so\n\n /*\n arm never goes to auto mode, so this is commented out\n\n (armState == AUTO) {\n //if the driver is attempting to cancel the task OR the task is done, return control\n //to the driver\n if (armJoystick.getRawButton(7) || !armTask.isRunning()) {\n armTask.interrupt();\n armTask.stop();\n armState = TELEOP;\n }\n }\n */\n\n //if drive is in teleop mode, handles input accordingly\n if (driveState == TELEOP) {\n try {\n handleDriveInput();\n } catch (EnhancedIOException e) {\n }\n\n }\n\n //if drive is in auto mode, checks whether user is trying to regain control\n /*not used\n if (driveState == AUTO) {\n //if the driver is attempting to cancel the task OR the task is done, return control\n //to the driver\n if (joysticks.getLeftButton(1) || !driveTask.isRunning()) {\n driveTask.interrupt();\n driveTask.stop();\n driveState = TELEOP;\n }\n }\n */\n\n\n printToScreen(\"Gyro Angle: \" + arm.gyro.getAngle());\n printToScreen(\"Arm Angle: \" + arm.getArmAngle());\n }", "public void gyroTurn ( double speed, double angle) {\n\n // keep looping while we are still active, and not on heading.\n while (opModeIsActive() && !onHeading(speed, angle, P_TURN_COEFF)) {\n // Update telemetry & Allow time for other processes to run.\n telemetry.addData(\"Direction\", gyro.getHeading());\n telemetry.update();\n }\n }", "@Override\n public void robotInit()\n {\n System.out.println(\"RoboRIO initializing...\");\n\n // initialize cameras\n camFront = CameraServer.getInstance().startAutomaticCapture(0);\n camBack = CameraServer.getInstance().startAutomaticCapture(1);\n camServForward = CameraServer.getInstance().getServer();\n camServReverse = CameraServer.getInstance().getServer();\n\n camServForward.setSource(camFront);\n //camServReverse.setSource(camBack);\n\n // init joysticks\n Joystick[] joysticks = getControllers();\n\n driveTrain = new DriveTrain();\n hatchArm = new HatchArm();\n cargoArm = new CargoArm();\n ramp = new Ramp();\n\n driver1 = new Buttons(joysticks[0]);\n driver2 = new Buttons(joysticks[1]);\n\n // init gyro\n // try\n // {\n // gyro = new AHRS(I2C.Port.kOnboard);\n // }\n // catch (RuntimeException ex)\n // {\n // // DriverStation.reportError(\"Error instantiating navX-MXP: \" + ex.getMessage(),\n // // true);\n // System.out.println(\"Error initializing gyro!\");\n // }\n\n // // update gyro info on smart dashboard\n // SmartDashboard.putNumber(\"X angle\", gyro.getYaw() + 180);\n // SmartDashboard.putNumber(\"Y angle\", gyro.getPitch() + 180);\n // SmartDashboard.putNumber(\"Z angle\", gyro.getRoll() + 180);\n \n // SmartDashboard.putNumber(\"X vel\", gyro.getVelocityX());\n // SmartDashboard.putNumber(\"Y vel\", gyro.getVelocityY());\n // SmartDashboard.putNumber(\"Z vel\", gyro.getVelocityZ());\n\n // SmartDashboard.putData(gyro);\n updateVars();\n updateShuffleboard();\n\n System.out.println(\"RoboRIO initialization complete.\");\n }", "@Override\n public void onSensorChanged(SensorEvent event) {\n timestamp = event.timestamp;\n gyroX = event.values[0];\n gyroY = event.values[1];\n gyroZ = event.values[2];\n\n this.setChanged();\n this.notifyObservers(Sensor.TYPE_GYROSCOPE);\n }", "public void updateIR() {\n\t\tfloat timeStart = System.nanoTime();\n\t\tfloat timeEnd;\n\t\tfloat timeElapsed;\n\t\tint remoteChan3 = infraredSensor.getRemotecmd(3);\n\t\tint remoteChan2 = infraredSensor.getRemotecmd(2);\n\t\tint remoteChan1 = infraredSensor.getRemotecmd(1);\n\t\tint remoteChan0 = infraredSensor.getRemotecmd(0);\n\t\tLCD.drawString(\"Hello\", 0, 0);\n\t\tLCD.drawInt(Channel, 0, 4);\n\n\t\tswitch (remoteChan3) {\n\t\t// Drive backward\n\t\tcase 1:\n\t\t\tdirection = 1;\n\t\t\tif (Record == true) {\n\t\t\t\tif (what != 1) {\n\t\t\t\t\ttimeEnd = System.nanoTime();\n\t\t\t\t\ttimeElapsed = timeEnd - timeStart;\n\t\t\t\t\trouteManager.Record(what, timeElapsed);\n\t\t\t\t}\n\t\t\t\ttimeStart = System.nanoTime();\n\t\t\t\twhat = 1;\n\t\t\t}\n\t\t\tbreak;\n\t\t// Drive forward\n\t\tcase 2:\n\t\t\tdirection = -1;\n\t\t\tif (Record == true) {\n\t\t\t\tif (what != 2) {\n\t\t\t\t\ttimeEnd = System.nanoTime();\n\t\t\t\t\ttimeElapsed = timeEnd - timeStart;\n\t\t\t\t\trouteManager.Record(what, timeElapsed);\n\t\t\t\t}\n\t\t\t\ttimeStart = System.nanoTime();\n\t\t\t\twhat = 2;\n\t\t\t}\n\t\t\tbreak;\n\t\t// Steer right\n\t\tcase 3:\n\t\t\tsteeringAngle = 30;\n\t\t\tif (Record == true) {\n\t\t\t\tif (what != 3) {\n\t\t\t\t\ttimeEnd = System.nanoTime();\n\t\t\t\t\ttimeElapsed = timeEnd - timeStart;\n\t\t\t\t\trouteManager.Record(what, timeElapsed);\n\t\t\t\t}\n\t\t\t\ttimeStart = System.nanoTime();\n\t\t\t\twhat = 3;\n\t\t\t}\n\t\t\tbreak;\n\t\t// Steer left\n\t\tcase 4:\n\t\t\tsteeringAngle = -30;\n\t\t\tif (Record == true) {\n\t\t\t\tif (what != 4) {\n\t\t\t\t\ttimeEnd = System.nanoTime();\n\t\t\t\t\ttimeElapsed = timeEnd - timeStart;\n\t\t\t\t\trouteManager.Record(what, timeElapsed);\n\n\t\t\t\t}\n\t\t\t\ttimeStart = System.nanoTime();\n\t\t\t\twhat = 4;\n\t\t\t}\n\t\t\tbreak;\n\t\t// Stop\n\t\tcase 9:\n\t\t\tdirection = 0;\n\t\t\tif (Record == true) {\n\t\t\t\tif (what != 9) {\n\t\t\t\t\ttimeEnd = System.nanoTime();\n\t\t\t\t\ttimeElapsed = timeEnd - timeStart;\n\t\t\t\t\trouteManager.Record(what, timeElapsed);\n\t\t\t\t}\n\t\t\t\ttimeStart = System.nanoTime();\n\t\t\t\twhat = 9;\n\t\t\t}\n\t\t\tbreak;\n\t\t}\n\n\t\tswitch (remoteChan2) {\n\t\t// start recording\n\t\tcase 1:\n\t\t\tRecord = true;\n\t\t\tSound.beep();\n\t\t\tbreak;\n\t\t// stop recording\n\t\tcase 2:\n\t\t\tRecord = false;\n\t\t\tbreak;\n\t\t// drive recorded route\n\t\tcase 3:\n\t\t\tRecord = false;\n\t\t\tSound.beep();\n\t\t\tSound.beep();\n\t\t\trouteManager.Play();\n\t\t\trouteManager.Play = true;\n\t\t\tbreak;\n\t\t// cancel current route\n\t\tcase 4:\n\t\t\trouteManager.Play = false;\n\t\t\tbreak;\n\t\t}\n\t\t// play prerecorded route\n\t\tswitch (remoteChan1) {\n\t\tcase 1:\n\t\t\trouteManager.Route1();\n\t\t\tbreak;\n\t\t}\n\t\t// play music\n\t\tswitch (remoteChan0) {\n\t\tcase 1:\n\t\t\tif (this.music.getState() == Thread.State.TERMINATED) {\n\t\t\t\tthis.music = new Music();\n\t\t\t} else if (!this.music.isAlive()) {\n\t\t\t\tthis.music.start();\n\t\t\t} else {\n\t\t\t\tDelay.msDelay(10);\n\t\t\t}\n\t\t\tbreak;\n\t\t}\n\n\t}", "void initialize() {\n setClockSource(MPU6050_CLOCK_PLL_INTERNAL);\n setFullScaleGyroRange(MPU6050_GYRO_FS_250);\n setFullScaleAccelRange(MPU6050_ACCEL_FS_2);\n }", "protected void initialize() {\n \t\n \ttimeStarted = System.currentTimeMillis();\n \tangle = driveTrain.gyro.getYaw();\n \tspeed = RobotMap.speedAtFullVoltage * power;\n \ttimeToGo = (long)(distance / speed) * 1000;\n }", "@Override\n public void runOpMode() throws InterruptedException {\n hMap(hardwareMap);\n ElapsedTime time = new ElapsedTime();\n\n\n\n markerDeploy.setPosition(0.25);\n latch.setPosition(0.25);\n rightBoxRotate.setPosition(.345);\n leftBoxRotate.setPosition(.655);\n\n\n /** Wait for the game to begin */\n telemetry.addData(\">\", \"Press Play to start tracking\");\n telemetry.update();\n waitForStart();\n\n rightBoxRotate.setPosition(0.15);\n leftBoxRotate.setPosition(0.85);\n\n motorArmLeft.setPower(0.5);\n motorArmRight.setPower(-0.5);\n Thread.sleep(1100);\n motorArmLeft.setPower(0);\n motorArmRight.setPower(0);\n\n\n Thread.sleep(100);\n\n\n // moveTo(0.4,20);\n\n\n // Thread.sleep(1000);\n\n\n rightBoxRotate.setPosition(.345);\n leftBoxRotate.setPosition(.655);\n\n Thread.sleep(100);\n\n motorArmLeft.setPower(0.5);\n motorArmRight.setPower(-0.5);\n Thread.sleep(1150);\n motorArmLeft.setPower(0);\n motorArmRight.setPower(0);\n\n Thread.sleep(250);\n\n setMotors(-0.4,-0.4);\n Thread.sleep(250);\n setMotors(0,0);\n\n Thread.sleep(250);\n\n motorArmLeft.setPower(0.5);\n motorArmRight.setPower(-0.5);\n Thread.sleep(475);\n motorArmLeft.setPower(0);\n motorArmRight.setPower(0);\n //up\n //servo init position\n Thread.sleep(250);\n\n motorArmLeft.setPower(-0.5);\n motorArmRight.setPower(0.5);\n Thread.sleep(200);\n motorArmLeft.setPower(0);\n motorArmRight.setPower(0);\n\n Thread.sleep(100);\n\n moveTo(0.4,200);\n\n// Thread.sleep(100);\n\n// rightBoxRotate.setPosition(0.15);\n// leftBoxRotate.setPosition(0.85);\n\n Thread.sleep(100);\n manip.setPower(1);\n }", "public void right90 () {\n saveHeading = 0; //modernRoboticsI2cGyro.getHeading();\n gyroTurn(TURN_SPEED, saveHeading - 90);\n gyroHold(HOLD_SPEED, saveHeading - 90, 0.5);\n }", "public void gyroHold( double speed, double angle, double holdTime) {\n\n ElapsedTime holdTimer = new ElapsedTime();\n\n // keep looping while we have time remaining.\n holdTimer.reset();\n while ((holdTimer.time() < holdTime)) {\n // Update telemetry & Allow time for other processes to run.\n onHeading(speed, angle, P_TURN_COEFF);\n try {\n sleep(50);\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n\n }\n\n // Stop all motion;\n leftmotor.setPower(0);\n rightmotor.setPower(0);\n }", "public void gyroHold( double speed, double angle, double holdTime) {\n\n ElapsedTime holdTimer = new ElapsedTime();\n\n // keep looping while we have time remaining.\n holdTimer.reset();\n while (opModeIsActive() && (holdTimer.time() < holdTime)) {\n // Update telemetry & Allow time for other processes to run.\n onHeading(speed, angle, P_TURN_COEFF);\n telemetry.update();\n }\n\n // Stop all motion;\n leftMotor.setPower(0);\n rightMotor.setPower(0);\n }", "public static final void control(float args_cmd_forward, float args_cmd_turn,\r\n\t\t\tfloat args_gyro, float args_gyro_offset, float args_theta_m_l,\r\n\t\t\tfloat args_theta_m_r, float args_battery) {\r\n\t\tfloat tmp_theta;\r\n\t\tfloat tmp_theta_lpf;\r\n\t\tfloat tmp_pwm_r_limiter;\r\n\t\tfloat tmp_psidot;\r\n\t\tfloat tmp_pwm_turn;\r\n\t\tfloat tmp_pwm_l_limiter;\r\n\t\tfloat tmp_thetadot_cmd_lpf;\r\n\t\tint tmp_0;\r\n\r\n\t\t/*\r\n\t\t * Sum: '<S8>/Sum' incorporates: Constant: '<S3>/Constant6' Constant:\r\n\t\t * '<S8>/Constant' Constant: '<S8>/Constant1' Gain: '<S3>/Gain1' Gain:\r\n\t\t * '<S8>/Gain2' Inport: '<Root>/cmd_forward' Product: '<S3>/Divide'\r\n\t\t * Product: '<S8>/Product' Sum: '<S8>/Sum1' UnitDelay: '<S8>/Unit Delay'\r\n\t\t */\r\n\t\ttmp_thetadot_cmd_lpf = (((args_cmd_forward / CMD_MAX) * K_THETADOT) * (1.0F - A_R))\r\n\t\t\t\t+ (A_R * ud_thetadot_cmd_lpf);\r\n\r\n\t\t/*\r\n\t\t * Gain: '<S4>/Gain' incorporates: Gain: '<S4>/deg2rad' Gain:\r\n\t\t * '<S4>/deg2rad1' Inport: '<Root>/theta_m_l' Inport: '<Root>/theta_m_r'\r\n\t\t * Sum: '<S4>/Sum1' Sum: '<S4>/Sum4' Sum: '<S4>/Sum6' UnitDelay:\r\n\t\t * '<S10>/Unit Delay'\r\n\t\t */\r\n\t\ttmp_theta = (((DEG2RAD * args_theta_m_l) + ud_psi) + ((DEG2RAD * args_theta_m_r) + ud_psi)) * 0.5F;\r\n\r\n\t\t/*\r\n\t\t * Sum: '<S11>/Sum' incorporates: Constant: '<S11>/Constant' Constant:\r\n\t\t * '<S11>/Constant1' Gain: '<S11>/Gain2' Product: '<S11>/Product' Sum:\r\n\t\t * '<S11>/Sum1' UnitDelay: '<S11>/Unit Delay'\r\n\t\t */\r\n\t\ttmp_theta_lpf = ((1.0F - A_D) * tmp_theta) + (A_D * ud_theta_lpf);\r\n\r\n\t\t/*\r\n\t\t * Gain: '<S4>/deg2rad2' incorporates: Inport: '<Root>/gyro'\r\n\t\t * Sum: '<S4>/Sum2'\r\n\t\t */\r\n\t\ttmp_psidot = (args_gyro - args_gyro_offset) * DEG2RAD;\r\n\r\n\t\t/*\r\n\t\t * Gain: '<S2>/Gain' incorporates: Constant: '<S3>/Constant2' Constant:\r\n\t\t * '<S3>/Constant3' Constant: '<S6>/Constant' Constant: '<S9>/Constant'\r\n\t\t * Gain: '<S1>/FeedbackGain' Gain: '<S1>/IntegralGain' Gain:\r\n\t\t * '<S6>/Gain3' Inport: '<Root>/battery' Product: '<S2>/Product'\r\n\t\t * Product: '<S9>/Product' Sum: '<S1>/Sum2' Sum: '<S1>/sum_err' Sum:\r\n\t\t * '<S6>/Sum2' Sum: '<S9>/Sum' UnitDelay: '<S10>/Unit Delay' UnitDelay:\r\n\t\t * '<S11>/Unit Delay' UnitDelay: '<S5>/Unit Delay' UnitDelay: '<S7>/Unit\r\n\t\t * Delay'\r\n\t\t */\r\n\t\ttmp[0] = ud_theta_ref;\r\n\t\ttmp[1] = 0.0F;\r\n\t\ttmp[2] = tmp_thetadot_cmd_lpf;\r\n\t\ttmp[3] = 0.0F;\r\n\t\ttmp_theta_0[0] = tmp_theta;\r\n\t\ttmp_theta_0[1] = ud_psi;\r\n\t\ttmp_theta_0[2] = (tmp_theta_lpf - ud_theta_lpf) / EXEC_PERIOD;\r\n\t\ttmp_theta_0[3] = tmp_psidot;\r\n\t\ttmp_pwm_r_limiter = 0.0F;\r\n\t\tfor (tmp_0 = 0; tmp_0 < 4; tmp_0++) {\r\n\t\t\ttmp_pwm_r_limiter += (tmp[tmp_0] - tmp_theta_0[tmp_0])\r\n\t\t\t\t\t* K_F[(tmp_0)];\r\n\t\t}\r\n\r\n\t\ttmp_pwm_r_limiter = (((K_I * ud_err_theta) + tmp_pwm_r_limiter) / ((BATTERY_GAIN * args_battery) - BATTERY_OFFSET)) * 100.0F;\r\n\r\n\t\t/*\r\n\t\t * Gain: '<S3>/Gain2' incorporates: Constant: '<S3>/Constant1' Inport:\r\n\t\t * '<Root>/cmd_turn' Product: '<S3>/Divide1'\r\n\t\t */\r\n\t\ttmp_pwm_turn = (args_cmd_turn / CMD_MAX) * K_PHIDOT;\r\n\r\n\t\t/* Sum: '<S2>/Sum' */\r\n\t\ttmp_pwm_l_limiter = tmp_pwm_r_limiter + tmp_pwm_turn;\r\n\r\n\t\t/* Saturate: '<S2>/pwm_l_limiter' */\r\n\t\ttmp_pwm_l_limiter = rt_SATURATE(tmp_pwm_l_limiter, -100.0F, 100.0F);\r\n\r\n\t\t/*\r\n\t\t * Outport: '<Root>/pwm_l' incorporates: DataTypeConversion: '<S1>/Data\r\n\t\t * Type Conversion'\r\n\t\t */\r\n\t\tpwm_l = (int) tmp_pwm_l_limiter;\r\n\r\n\t\t/* Sum: '<S2>/Sum1' */\r\n\t\ttmp_pwm_r_limiter -= tmp_pwm_turn;\r\n\r\n\t\t/* Saturate: '<S2>/pwm_r_limiter' */\r\n\t\ttmp_pwm_r_limiter = rt_SATURATE(tmp_pwm_r_limiter, -100.0F, 100.0F);\r\n\r\n\t\t/*\r\n\t\t * Outport: '<Root>/pwm_r' incorporates: DataTypeConversion: '<S1>/Data\r\n\t\t * Type Conversion6'\r\n\t\t */\r\n\t\tpwm_r = (int) tmp_pwm_r_limiter;\r\n\r\n\t\t/*\r\n\t\t * Sum: '<S7>/Sum' incorporates: Gain: '<S7>/Gain' UnitDelay: '<S7>/Unit\r\n\t\t * Delay'\r\n\t\t */\r\n\t\ttmp_pwm_l_limiter = (EXEC_PERIOD * tmp_thetadot_cmd_lpf) + ud_theta_ref;\r\n\r\n\t\t/*\r\n\t\t * Sum: '<S10>/Sum' incorporates: Gain: '<S10>/Gain' UnitDelay:\r\n\t\t * '<S10>/Unit Delay'\r\n\t\t */\r\n\t\ttmp_pwm_turn = (EXEC_PERIOD * tmp_psidot) + ud_psi;\r\n\r\n\t\t/*\r\n\t\t * Sum: '<S5>/Sum' incorporates: Gain: '<S5>/Gain' Sum: '<S1>/Sum1'\r\n\t\t * UnitDelay: '<S5>/Unit Delay' UnitDelay: '<S7>/Unit Delay'\r\n\t\t */\r\n\t\ttmp_pwm_r_limiter = ((ud_theta_ref - tmp_theta) * EXEC_PERIOD)\r\n\t\t\t\t+ ud_err_theta;\r\n\r\n\t\t/* user code (Update function Body) */\r\n\t\t/* System '<Root>' */\r\n\t\t/* 次回演算用状態量保存処理 */\r\n\r\n\t\t/* Update for UnitDelay: '<S5>/Unit Delay' */\r\n\t\tud_err_theta = tmp_pwm_r_limiter;\r\n\r\n\t\t/* Update for UnitDelay: '<S7>/Unit Delay' */\r\n\t\tud_theta_ref = tmp_pwm_l_limiter;\r\n\r\n\t\t/* Update for UnitDelay: '<S8>/Unit Delay' */\r\n\t\tud_thetadot_cmd_lpf = tmp_thetadot_cmd_lpf;\r\n\r\n\t\t/* Update for UnitDelay: '<S10>/Unit Delay' */\r\n\t\tud_psi = tmp_pwm_turn;\r\n\r\n\t\t/* Update for UnitDelay: '<S11>/Unit Delay' */\r\n\t\tud_theta_lpf = tmp_theta_lpf;\r\n\t}", "protected void end() {\n \tSystem.out.println(\"Gyro: \" + Drivetrain.gyro.getAngle());\n \tDrivetrain.gyro.reset();\n \tDrivetrain.frontRight.set(ControlMode.PercentOutput, 0.0);\n\t\tDrivetrain.rearRight.set(ControlMode.PercentOutput, 0.0);\n\t\tDrivetrain.frontLeft.set(ControlMode.PercentOutput, 0.0);\n\t\tDrivetrain.rearLeft.set(ControlMode.PercentOutput, 0.0);\n \t\n }", "@Override\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Resetting Encoders\"); //\n telemetry.update();\n\n leftFront = hardwareMap.get(DcMotor.class, \"left_front\");\n rightFront = hardwareMap.get(DcMotor.class, \"right_front\");\n leftBack = hardwareMap.get(DcMotor.class, \"left_back\");\n rightBack = hardwareMap.get(DcMotor.class, \"right_back\");\n\n\n leftFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n rightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n leftBack.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n rightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n\n right = hardwareMap.get(Servo.class, \"right\");\n left = hardwareMap.get(Servo.class, \"left\");\n // Most robots need the motor on one side to be reversed to drive forward\n // Reverse the motor that runs backwards when connected directly to the battery\n leftFront.setDirection(DcMotor.Direction.REVERSE);\n rightFront.setDirection(DcMotor.Direction.FORWARD);\n leftBack.setDirection(DcMotor.Direction.REVERSE);\n rightBack.setDirection(DcMotor.Direction.FORWARD);\n\n leftFront.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n leftBack.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n rightFront.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n rightBack.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n digitalTouch = hardwareMap.get(DigitalChannel.class, \"sensor_digital\");\n digitalTouch.setMode(DigitalChannel.Mode.INPUT);\n\n right.setDirection(Servo.Direction.REVERSE);\n\n right.scaleRange(0, 0.25);\n left.scaleRange(0.7, 1);\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n\n servo(0);\n runtime.reset();\n encoderSideways(0.25, -5, -5, 5);\n // drive until touch sensor pressed\n // activate servos to grab platform\n // drive backwards for a while\n // release servos\n // sideways part\n // remember to do red autonomous for repackage org.firstinspires.ftc.teamcode;\n }", "@Override\n public void init_loop() {\n\n\n if (robot.gyro.isCalibrating()) {\n telemetry.addData(\"we calibrating\", \"\");\n } else {\n telemetry.addData(\"Hell naw\", \"\");\n }\n telemetry.update();\n\n\n // Send telemetry message to signify robot waiting;\n // telemetry.addData(\"Say\", \"Dick\"); //\n // telemetry.update();\n\n // Wait for the game to start (driver presses PLAY)\n\n\n // run until the end of the match (driver presses STOP)\n }", "public void robotInit() {\n ;\n System.out.println(\"robot_init\");\n liftJoystick = new Joystick(2);\n armJoystick = new Joystick(4);\n setEncoder(new Encoder(2, 3));\n getEncoder().setDistancePerPulse(8.0 * 3.14 / 360.0 / 2);\n compressor = new Compressor(1, 1);\n compressor.start();\n // cameraMount = new CameraMount(10,9);\n //File file = new File (\"WALT_output.txt\");\n displayIndex = 1;\n driverScreen = DriverStationLCD.getInstance();\n\n //sensor wiring was switche so I fixed it programming wise\n setLeft(new DigitalInput(12));\n if (getLeft() == null) {\n printToScreen(\"LEFT SENSOR [DigitalInput(12)] IS NULL!!\");\n } else {\n printToScreen(\"LEFT SENSOR [DigitalInput(12)] is initialized\");\n }\n\n middle = new DigitalInput(13);\n if (getMiddle() == null) {\n printToScreen(\"MIDDLE SENSOR [DigitalInput(13)] IS NULL!!\");\n } else {\n printToScreen(\"MIDDLE SENSOR [DigitalInput(13)] is initialized\");\n }\n\n right = new DigitalInput(14);\n if (getRight() == null) {\n printToScreen(\"RIGHT SENSOR [DigitalInput(14)] IS NULL!!\");\n } else {\n printToScreen(\"RIGHT SENSOR [DigitalInput(14)] INITIALIZED\");\n }\n\n demoMode = false;\n myDog = Watchdog.getInstance();\n myDog.setEnabled(true);\n myDog.setExpiration(1);\n joysticks = new TankControls(1, 3);//All channel values arbitrary at this point and may need to be changed.\n // xboxController = new XboxControls(3);//channel value\n //initializes pneumatics\n //int[] solenoidChannels=(4,5);\n int spikeChannel = 1;\n int pressureSwitch = 2;\n //pneumatics=new pneumaticSystem(solenoidChannels,spikeChannel,pressureSwitch, 120);\n\n //Arm constructor\n //currently the arm is controlling the drive motors- arm channels are 3,4\n int liftChannel = 3;\n int armChannel = 4;\n int solenoidChannelWrist = 1;\n int clawSolenoid = 2;\n int armGyroChannel = 2;\n arm = new Arm(liftChannel, armChannel, solenoidChannelWrist,\n clawSolenoid, armGyroChannel);\n //channel for gyro\n int gyroChannel = 1;\n\n //channels for camera initiation\n boolean usingCamera = true;\n int panMotorCamChannel = 9;\n int tiltCamChannel = 8;\n\n //channels for accelerators- may want multiple for multiple directions\n int accSlot = -1;\n\n setSensors(new SensorSet(gyroChannel, accSlot, usingCamera,\n tiltCamChannel, panMotorCamChannel));\n\n setRobotDrive(new TwoMotorDrive(1, 2, demoMode));\n getRobotDrive().setInvertedSide(true);//boolean is true to invert right, false for left\n\n //so that it doesn't return nulls- should not be started before re-creating Why do we initialize it here then?\n driveTask = new WaltLineTrack(false, false, this);\n armTask = arm.getNewGoToHeightInstance(2);\n armTask2 = arm.getNewGoToAngleInstance(135);\n }", "@Override\n public void runOpMode() {\n detector = new modifiedGoldDetector(); //Create detector\n detector.init(hardwareMap.appContext, CameraViewDisplay.getInstance(), DogeCV.CameraMode.BACK); //Initialize it with the app context and camera\n detector.enable(); //Start the detector\n\n //Initialize the drivetrain\n motorFL = hardwareMap.get(DcMotor.class, \"motorFL\");\n motorFR = hardwareMap.get(DcMotor.class, \"motorFR\");\n motorRL = hardwareMap.get(DcMotor.class, \"motorRL\");\n motorRR = hardwareMap.get(DcMotor.class, \"motorRR\");\n motorFL.setDirection(DcMotor.Direction.REVERSE);\n motorFR.setDirection(DcMotor.Direction.FORWARD);\n motorRL.setDirection(DcMotor.Direction.REVERSE);\n motorRR.setDirection(DcMotor.Direction.FORWARD);\n\n //Reset encoders\n motorFL.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorFR.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorRL.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorRR.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorFL.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorFR.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorRL.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorRR.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n telemetry.addData(\"IsFound: \", detector.isFound());\n telemetry.addData(\">\", \"Waiting for start\");\n telemetry.update();\n\n\n //TODO Pass skystone location to storage\n\n //Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n /**\n * *****************\n * OpMode Begins Here\n * *****************\n */\n\n //Disable the detector\n if(detector != null) detector.disable();\n\n //Start the odometry processing thread\n odometryPositionUpdate positionUpdate = new odometryPositionUpdate(motorFL, motorFR, motorRL, motorRR, inchPerCount, trackWidth, wheelBase, 75);\n Thread odometryThread = new Thread(positionUpdate);\n odometryThread.start();\n runtime.reset();\n\n //Run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n\n absPosnX = startPosnX + positionUpdate.returnOdometryX();\n absPosnY = startPosnY + positionUpdate.returnOdometryY();\n absPosnTheta = startPosnTheta + positionUpdate.returnOdometryTheta();\n\n telemetry.addData(\"X Position [in]\", absPosnX);\n telemetry.addData(\"Y Position [in]\", absPosnY);\n telemetry.addData(\"Orientation [deg]\", absPosnTheta);\n telemetry.addData(\"Thread Active\", odometryThread.isAlive());\n telemetry.update();\n\n//Debug: Drive forward for 3.0 seconds and make sure telemetry is correct\n if (runtime.seconds() < 3.0) {\n motorFL.setPower(0.25);\n motorFR.setPower(0.25);\n motorRL.setPower(0.25);\n motorRR.setPower(0.25);\n }else {\n motorFL.setPower(0);\n motorFR.setPower(0);\n motorRL.setPower(0);\n motorRR.setPower(0);\n }\n\n\n }\n //Stop the odometry processing thread\n odometryThread.interrupt();\n }", "@Override\n\tpublic void testPeriodic(){\n\t\t//Testing xbox buttons, joysticks and triggers\n\t\tOI.refreshAll();\n//\t\t//System.out.println(\"Left Y = \" + xbox.LeftStick.Y);\n//\t\t//System.out.println(\"Right Y = \" + xbox.RightStick.Y);\n//\t\t\n//\t\t\n//\t\tfinal double cpr = 360.0;\n//\t\tfinal double encoder_angular_distance_per_pulse = 2.0*Math.PI / cpr;\n//\t\tfinal double wheel_radius = 2.5; // .564 in (18T 5mm pitch)\n//\t\tfinal double encLinearDistancePerPulse = wheel_radius * encoder_angular_distance_per_pulse; //2.0 * Math.PI / cpr;\n//\t\t\n//\t\tSystem.out.println(enc.getRaw()*encLinearDistancePerPulse);\n//\t\t\n\t\t\n\t\t//System.out.println(gyro.getAngle(MPU6050.Axis.X));\n\n\t //PNEUMATICS\n\t //c.setClosedLoopControl(true);\n\t //c.setClosedLoopControl(false);\n\t}", "@Override\npublic void teleopPeriodic() {\nm_robotDrive.arcadeDrive(m_stick.getRawAxis(5)* (-0.5), m_stick.getRawAxis(4)*0.5);\n}", "public Gyro360 (AnalogChannel channel) {\n super(channel);\n }", "protected void initialize() {\n \tRobot.driveBase.resetEnc(2);\n \tRobot.gyro.reset();\n \t//stop extraneous moving parts\n }" ]
[ "0.73942494", "0.7036652", "0.68824184", "0.6785464", "0.67816496", "0.6558956", "0.6517386", "0.65114707", "0.6470462", "0.6358405", "0.63164425", "0.6288348", "0.62445015", "0.6179822", "0.61791563", "0.6098057", "0.60874397", "0.60861856", "0.6081984", "0.60748076", "0.6073459", "0.6066034", "0.6030548", "0.6029562", "0.6013447", "0.6013435", "0.6008216", "0.5990768", "0.59874713", "0.5986681", "0.5976136", "0.59611416", "0.59491426", "0.5936014", "0.59124076", "0.59115714", "0.59100085", "0.5908106", "0.5900803", "0.5892917", "0.5890924", "0.5880573", "0.58749676", "0.58738756", "0.58461803", "0.5841375", "0.5834903", "0.5823448", "0.5820695", "0.58152664", "0.5809069", "0.5807306", "0.5799996", "0.5796624", "0.57949555", "0.5788792", "0.5784945", "0.5771484", "0.5770337", "0.5764187", "0.57584834", "0.57519794", "0.5747757", "0.5745408", "0.57446086", "0.57422227", "0.5735422", "0.5734432", "0.57327807", "0.5723006", "0.5713158", "0.5697054", "0.5687853", "0.5686887", "0.56813306", "0.56759053", "0.5674921", "0.5673678", "0.56687397", "0.5667409", "0.566557", "0.56536126", "0.5638794", "0.5625708", "0.56245816", "0.5616368", "0.5592175", "0.55867994", "0.55825835", "0.55794406", "0.5578885", "0.55767107", "0.5575985", "0.557476", "0.5569605", "0.5559627", "0.5548266", "0.55437845", "0.55368847", "0.553256", "0.55304235" ]
0.0
-1
/ This method will be called repeatedly in a loop SUNLIGHTU YELLOW
@Override public void loop() { // throttle: left_stick_y ranges from -1 to 1, where -1 is full up, and // 1 is full down // direction: left_stick_x ranges from -1 to 1, where -1 is full left // and 1 is full right double y1 = -gamepad1.left_stick_y; double x1 = gamepad1.left_stick_x; double y2 = -gamepad1.right_stick_y; double x2 = gamepad1.right_stick_x; //This one is for turning double treadStickValueR = 0; double treadStickValueL = 0; boolean leftBumper = gamepad2.left_bumper; boolean rightBumper = gamepad2.right_bumper; boolean aButton = gamepad1.a; boolean bButton = gamepad1.b; /** if (gamepad2.right_bumper) rightBumper = true; else { rightBumper = false; } if (gamepad2.left_bumper) leftBumper = true; else { leftBumper = false; } */ double armStickValue = -gamepad2.right_stick_y; //input for raising/lowering arm if (gamepad2.left_trigger != 0) { treadStickValueR = -gamepad2.left_trigger; //input for changing tread speed treadStickValueL = -gamepad2.left_trigger; //input for changing tread speed } else { treadStickValueR = gamepad2.right_trigger; //input for changing tread speed treadStickValueL = gamepad2.right_trigger; //input for changing tread speed } /** boolean dpadUP = gamepad1.dpad_up; boolean dpadDOWN = gamepad1.dpad_down; boolean dpadLEFT = gamepad1.dpad_left; boolean dpadRIGHT = gamepad1.dpad_right; */ //On a scale of 1, -1, if it's less than 0.05, then it may be 0 in reality. 12.75 in 255 land if (Math.abs(x1) <= 0.1 * MAX) x1 = 0; if (Math.abs(y1) <= 0.1 * MAX) y1 = 0; if (Math.abs(x2) <= 0.1 * MAX) x2 = 0; if (Math.abs(y2) <= 0.1 * MAX) y2 = 0; if (Math.abs(armStickValue) <= 0.05 * MAX) armStickValue = 0; if (Math.abs(treadStickValueR) <= 0.05 * MAX) treadStickValueR = 0; if (Math.abs(treadStickValueL) <= 0.05 * MAX) treadStickValueL = 0; boolean LeftBumpVal = leftBumper; boolean RightBumpVal = rightBumper; //Decides direction by splitting circle into four quadrants, and assumes that the stick is pushed to the edge of the circle for precision between quadrants //See unit circle to explain why x must be less than or greater than Rt(2)/2 if (y1 > 0) //Joystick forwards if (x1 < -(Math.sqrt(2) / 2)) //Moving straight left { FLval = -Math.round(Math.abs(x1 * 10)) / 10.0; FRval = Math.round(Math.abs(x1 * 10)) / 10.0; BLval = Math.round(Math.abs(x1 * 10)) / 10.0; BRval = -Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else if (x1 > (Math.sqrt(2) / 2)) //Moving right { FLval = Math.round(Math.abs(x1 * 10)) / 10.0; FRval = -Math.round(Math.abs(x1 * 10)) / 10.0; BLval = -Math.round(Math.abs(x1 * 10)) / 10.0; BRval = Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else //Forwards { FLval = Math.round(Math.abs(y1 * 10)) / 10.0; FRval = Math.round(Math.abs(y1 * 10)) / 10.0; BLval = Math.round(Math.abs(y1 * 10)) / 10.0; BRval = Math.round(Math.abs(y1 * 10)) / 10.0; } else if (y1 < 0) //Stick backwards if (x1 < -(Math.sqrt(2) / 2)) //Straight left { FLval = -Math.round(Math.abs(x1 * 10)) / 10.0; FRval = Math.round(Math.abs(x1 * 10)) / 10.0; BLval = Math.round(Math.abs(x1 * 10)) / 10.0; BRval = -Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else if (x1 > (Math.sqrt(2) / 2)) //Right { FLval = Math.round(Math.abs(x1 * 10)) / 10.0; FRval = -Math.round(Math.abs(x1 * 10)) / 10.0; BLval = -Math.round(Math.abs(x1 * 10)) / 10.0; BRval = Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else //Backwards { FLval = -Math.round(Math.abs(y1 * 10)) / 10.0; FRval = -Math.round(Math.abs(y1 * 10)) / 10.0; BLval = -Math.round(Math.abs(y1 * 10)) / 10.0; BRval = -Math.round(Math.abs(y1 * 10)) / 10.0; } else //stick not moved vertically if (x1 > 0) { //Right FLval = Math.round(Math.abs(x1 * 10)) / 10.0; FRval = -Math.round(Math.abs(x1 * 10)) / 10.0; BLval = -Math.round(Math.abs(x1 * 10)) / 10.0; BRval = Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else if (x1 < 0) { //Left FLval = -Math.round(Math.abs(x1 * 10)) / 10.0; FRval = Math.round(Math.abs(x1 * 10)) / 10.0; BLval = Math.round(Math.abs(x1 * 10)) / 10.0; BRval = -Math.round(Math.abs(x1 * 10)) / 10.0; FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } else { //Stick at origin FLval = 0; FRval = 0; BLval = 0; BRval = 0; } //Right now turning overrides other movement if (x2 != 0) //Turning { FRval = FORWARD_POWER * -(x2 / (Math.abs(x2))); FLval = FORWARD_POWER * (x2 / (Math.abs(x2))); BRval = FORWARD_POWER * -(x2 / (Math.abs(x2))); BLval = FORWARD_POWER * (x2 / (Math.abs(x2))); FLval = FLval*SPEED_MODIFIER; FRval = FRval*SPEED_MODIFIER; BLval = BLval*SPEED_MODIFIER; BRval = BRval*SPEED_MODIFIER; } //For changing tread speed TLval = treadStickValueL; TRval = -treadStickValueR; //For changing arm value armVal = armStickValue; Range.clip(FLval, -CLIP_NUM, CLIP_NUM); //This is to make sure that no STRANGE values somehow get in Range.clip(BLval, -CLIP_NUM, CLIP_NUM); Range.clip(BRval, -CLIP_NUM, CLIP_NUM); Range.clip(FRval, -CLIP_NUM, CLIP_NUM); /* boolean imaniDoesNotCareForHerOwnSafety = gamepad2.a; if ((lastWasForSlow && !imaniDoesNotCareForHerOwnSafety) || (lastWasBackSlow && !gamepad2.y)) spikeTime = 0; */ FrontRight.setPower(FRval); FrontLeft.setPower(FLval); BackRight.setPower(BRval); BackLeft.setPower(BLval); TreadLeft.setPower(TLval); TreadRight.setPower(TRval); ArmMotor.setPower(armVal); boolean lastResetState = false; boolean curResetState = false; /** // Get a reference to a Modern Robotics gyro object. We use several interfaces // on this object to illustrate which interfaces support which functionality. gyro = hardwareMap.get(IntegratingGyroscope.class, "gyro"); modernRoboticsI2cGyro = hardwareMap.get(ModernRoboticsI2cGyro.class, "gyro"); gyro = (IntegratingGyroscope) modernRoboticsI2cGyro; // If you're only interested in the IntegratingGyroscope interface, the following will suffice. // A similar approach will work for the Gyroscope interface, if that's all you need. // Start calibrating the gyro. This takes a few seconds and is worth performing // during the initialization phase at the start of each opMode. telemetry.log().add("Gyro Calibrating. Do Not Move!"); modernRoboticsI2cGyro.calibrate(); // Wait until the gyro calibration is complete timer.reset(); while (modernRoboticsI2cGyro.isCalibrating()) { telemetry.addData("calibrating", "%s", Math.round(timer.seconds()) % 2 == 0 ? "|.." : "..|"); telemetry.update(); } telemetry.log().clear(); telemetry.log().add("Gyro Calibrated. Press Start."); telemetry.clear(); telemetry.update(); // Wait for the start button to be pressed telemetry.log().clear(); telemetry.log().add("Press A & B to reset heading"); // If the A and B buttons are pressed just now, reset Z heading. curResetState = (gamepad1.a && gamepad1.b); if (curResetState && !lastResetState) { modernRoboticsI2cGyro.resetZAxisIntegrator(); } lastResetState = curResetState; // The raw() methods report the angular rate of change about each of the // three axes directly as reported by the underlying sensor IC. int rawX = modernRoboticsI2cGyro.rawX(); int rawY = modernRoboticsI2cGyro.rawY(); int rawZ = modernRoboticsI2cGyro.rawZ(); int heading = modernRoboticsI2cGyro.getHeading(); int integratedZ = modernRoboticsI2cGyro.getIntegratedZValue(); // Read dimensionalized data from the gyro. This gyro can report angular velocities // about all three axes. Additionally, it internally integrates the Z axis to // be able to report an absolute angular Z orientation. AngularVelocity rates = gyro.getAngularVelocity(AngleUnit.DEGREES); float zAngle = gyro.getAngularOrientation(AxesReference.INTRINSIC, AxesOrder.ZYX, AngleUnit.DEGREES).firstAngle; // Read administrative information from the gyro int zAxisOffset = modernRoboticsI2cGyro.getZAxisOffset(); int zAxisScalingCoefficient = modernRoboticsI2cGyro.getZAxisScalingCoefficient(); telemetry.addLine() .addData("dx", (rates.xRotationRate)) .addData("dy", (rates.yRotationRate)) .addData("dz", "%s deg/s", (rates.zRotationRate)); telemetry.addData("angle", "%s deg", (zAngle)); telemetry.addData("heading", "%3d deg", heading); telemetry.addData("integrated Z", "%3d", integratedZ); telemetry.addLine() .addData("rawX", (rawX)) .addData("rawY", (rawY)) .addData("rawZ", (rawZ)); telemetry.addLine().addData("z offset", zAxisOffset).addData("z coeff", zAxisScalingCoefficient); telemetry.update(); **/ telemetry.addData("Front Left: ", FLval); telemetry.addData("Front Right: ", FRval); telemetry.addData("Back Left: ", BLval); telemetry.addData("Back Right: ", BRval); telemetry.addData("Tread Left: ", TLval); telemetry.addData("Tread Right: ", TRval); telemetry.addData("Arm: ", armVal); telemetry.addData("xLeft: ", x1); telemetry.addData("yLeft: ", y1); telemetry.addData("xRight: ", x2); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void periodic() {\n\n if (lastcolor != sColor())\n {\n lastcolor = sColor();\n colorcount++;\n }\n\n DriverStation.reportError(sColor() + /*\",\" + sRGB() +*/ \", \" + sIsClose() + \",\" + String.valueOf(colorcount), false);\n\n\n \n }", "@Override\n void individualUpdate() {\n timeToLive--;\n radius++;\n setColor();\n }", "public void run() {\n while (true) {\n lcd.clear();\n int[] colorIds = new int [15];\n for (int i = 0; i < colorIds.length;i++) {\n colorIds[colorSensor.getColorID()+1] += 1;\n int currentMax = colorIds[0];\n int currentMaxIndex = 0;\n for(int j = 1; j < colorIds.length; j++) {\n if(colorIds[j] > currentMax) {\n currentMaxIndex = j;\n currentMax = colorIds[j];\n }\n }\n String color = getColorString(currentMaxIndex);\n //if (color.equals(\"Black\"))\n //DriveUtil.setSpeed(80);\n if (color.equals(\"Orange\") || color.equals(\"Green\") || color.equals(\"Yellow\") || color.equals(\"Blue\")) {\n //DriveUtil.stopMotors();\n DriveUtil.setSpeed(1);\n lcd.drawString(\"Object Detected\", 1, 1);\n lcd.drawString(color, 1, 2);\n colorsDetected.add(color);\n Sound.twoBeeps();\n try {\n Thread.sleep(10000);\n } catch (InterruptedException e) {\n e.printStackTrace();\n }\n DriveUtil.setSpeed(FORWARD_SPEED);\n //break;\n }\n }\n }\n }", "private void yellow(){\n\t\tthis.arretes_fY();\n\t\tthis.coins_fY();\n\t\tthis.coins_a1Y();\n\t\tthis.coins_a2Y();\n\t\tthis.aretes_aY();\n\t\tthis.cube[49] = \"Y\";\n\t}", "protected void runEachSecond() {\n \n }", "public void Color() {\n\t\t\r\n\t}", "synchronized private void changeColor()\n {\n if ( ++colorIndex == someColors.length )\n colorIndex = 0;\n setForeground( currentColor() );\n repaint();\n }", "private void green(){\n\t\tthis.arretes_fG();\n\t\tthis.coins_fG();\n\t\tthis.coins_a1G();\n\t\tthis.coins_a2G();\n\t\tthis.aretes_aG();\n\t\tthis.cube[31] = \"G\";\n\t}", "@Override\n public void periodic() {\n\n colorCalibrationEnabled = ntColorCalibrationEnabled.getBoolean(false);\n\n /* NON-OPERATIONAL SENSOR\n colorMatchResult = colorMatcher.matchClosestColor(colorSensor.getColor());\n */\n\n if(colorMatchResult.color == kRedTarget)\n {\n colorIsRed = true;\n colorIsGreen = false;\n colorIsBlue = false;\n colorIsYellow = false;\n }\n else if(colorMatchResult.color == kGreenTarget)\n {\n colorIsRed = false;\n colorIsGreen = true;\n colorIsBlue = false;\n colorIsYellow = false;\n }\n else if(colorMatchResult.color == kBlueTarget)\n {\n colorIsRed = false;\n colorIsGreen = false;\n colorIsBlue = true;\n colorIsYellow = false;\n }\n else if(colorMatchResult.color == kYellowTarget)\n {\n colorIsRed = false;\n colorIsGreen = false;\n colorIsBlue = false;\n colorIsYellow = true;\n }\n\n ntColorIsRed.setBoolean(colorIsRed);\n ntColorIsGreen.setBoolean(colorIsGreen);\n ntColorIsBlue.setBoolean(colorIsBlue);\n ntColorIsYellow.setBoolean(colorIsYellow);\n\n colorCalibration();\n\n numberOfTurnsToRotate = ntScdNumberOfTurnsToRotate.getDouble(69.0);\n ntStsNumberOfTurnsToRotate.forceSetDouble(numberOfTurnsToRotate);\n }", "@Override\n\tpublic void run() {\n\t\tfor(int i=0; i<views.length; i++){\n\t\t\tviews[i].setBackgroundColor(getResources().getColor(colors[(i+color_offset_index)%(views.length)]));\t\n\t\t}\n\n\t\thandler.postDelayed(this, 500);\n\t\tcolor_offset_index++;\n//\t\tif(color_offset_index >= views.length){//可有可无,即使溢出也从0重新开始\n//\t\t\tcolor_offset_index = 0;\n//\t\t}\n\t}", "public void turnOnce() {\n\n Color currentColor = colorSensor.getColor();\n int colorChange = 0;\n // TODO: You can increase the speed here depending on how good the color sensor\n // reads color changes for added efficency.\n wheelTurner.set(.25);\n\n while (colorChange < 9) {\n ColorMatchResult match = colorMatcher.matchClosestColor(colorSensor.getColor());\n // checks if the current color that is being sensed checks out with our stored\n if (match != colorMatcher.matchClosestColor(currentColor)) {\n colorChange++;\n currentColor = colorSensor.getColor();\n }\n\n }\n wheelTurner.stopMotor();\n }", "@Override public void loop() {\n }", "public void loop(){\n \n \n }", "public void endYellow() {\n if (System.currentTimeMillis() - lastAttack > 200) {\n isYellow = false;\n ((Geometry)model.getChild(\"Sphere\")).getMaterial().setColor(\"Color\", ColorRGBA.Red);\n }\n }", "public void loop(){\n\t\t\n\t}", "@Override\n public void loop()\n {\n }", "@Override public void loop () {\n }", "public void onRepeat() {\n\t\t// TODO Auto-generated method stub\n\t\tLastWholeDelta = 0;\n\t}", "private void loop() {\n mStateTimeTextView.setText(\"\" + getStateTimeMs() / 1000);\n\n switch (mState) {\n case SEEKING_HOME:\n // Really this is the area to check your GPS and heading and drive the wheels.\n\n if (getStateTimeMs() > 6000) {\n setState(State.READY);\n }\n break;\n default:\n // Catch for all the states that you know do nothing\n break;\n }\n\n }", "public void applyColor() {\n\t\tSystem.out.println(\"Yellow\");\n\n\t}", "@Override\n public void loop() {\n\n }", "@Override\n public void loop() {\n\n }", "@Override\n public void run(){\n store.phaser.arriveAndAwaitAdvance();\n //System.out.println(Thread.currentThread().getName() + \" is started.\");\n for(int y = startLine; y < endLine; y++){\n for(int x = 0; x < store.image.getWidth(); x++){\n Color c = new Color(store.image.getRGB(x, y));\n int grayScale = (int) ((c.getRed() * 0.299) + (c.getGreen() * 0.587) + (c.getBlue() * 0.114));\n Color newColor = new Color(grayScale, grayScale, grayScale);\n store.image.setRGB(x, y, newColor.getRGB());\n }\n }\n store.phaser.arriveAndAwaitAdvance();\n }", "private void red(){\n\t\tthis.arretes_fR();\n\t\tthis.coins_fR();\n\t\tthis.coins_a1R();\n\t\tthis.coins_a2R();\n\t\tthis.aretes_aR();\n\t\tthis.cube[13] = \"R\";\n\t}", "@Override\n\tpublic void yellow() {\n\t\tSystem.out.println(\"Yellow Light\");\n\t\t\n\t}", "@Override\n public void run() {\n threadRunning = true;\n //Color clr = new Color();\n\n while (threadRunning){\n\n colorRGBSensor.fetchSample(sample, 0);\n color.setR(sample[0]*1024);\n color.setG(sample[1]*1024);\n color.setB(sample[2]*1024);\n\n synchronized (this){\n setColor(color);\n }\n\n try {\n Thread.sleep(Constants.LIGHT_SENSOR_UPDATE_TIME);\n } catch (Exception e) {\n }\n }\n }", "@Override\n\t\tpublic void run() {\n\t\t\tisRepeatFlag = true;\n\t\t}", "void oscillate( float redColor, float greenColor, float blueColor ) {\n\t\t\tr = redColor;\n\t\t\tg = greenColor;\n\t\t\tb = blueColor;\n\t\t}", "public void step()\n {\n LCD.clear();\n sw.reset();\n for( int i = 0; i<3; i++)m[i].resetTachoCount();\n for( int i = 0; i<3; i++)m[i].forward();\n for(int r = 0 ; r<8; r++)\n {\n while(sw.elapsed() < 200* r)Thread.yield();\n for( int i = 0; i<3; i++)\n LCD.drawInt(m[i].getTachoCount(),5*i,r);\n }\n for( int i = 0; i<3; i++)m[i].stop();\n Button.waitForPress();\n }", "void setColor(){\n this.objectColour = new Color(rValue,gValue,bValue,timeToLive).brighter();\n }", "public void changeBackgroudColorForTimeInSec(double time) {\n long timeLong = (long) (time * 1000);\n\n // make vibration\n Vibrator v = (Vibrator) getSystemService(Context.VIBRATOR_SERVICE);\n // Vibrate for 500 milliseconds\n if (Build.VERSION.SDK_INT >= Build.VERSION_CODES.O) {\n v.vibrate(VibrationEffect.createOneShot(500, VibrationEffect.DEFAULT_AMPLITUDE));\n } else {\n //deprecated in API 26\n v.vibrate(500);\n }\n\n //play sound\n MediaPlayer mediaPlayer = MediaPlayer.create(this, R.raw.moonless);\n mediaPlayer.start();\n\n //change color\n scroolViewScanner.setBackgroundColor(Color.RED);\n scroolViewDefect.setBackgroundColor(Color.RED);\n linLayOverView.setBackgroundColor(Color.RED);\n Handler handler = new Handler();\n handler.postDelayed(new Runnable() {\n public void run() {\n // Actions to do after\n scroolViewScanner.setBackgroundColor(Color.TRANSPARENT);\n scroolViewDefect.setBackgroundColor(Color.TRANSPARENT);\n linLayOverView.setBackgroundColor(Color.TRANSPARENT);\n }\n }, timeLong); // delay\n }", "private void loop() {\r\n\t\tfloat elapsed;\r\n\t\tfloat accumulated = 0f;\r\n\t\tfloat interval = 1f / TARGET_UPS;\r\n\t\tdouble time;\r\n\t\tdouble lastCall = System.nanoTime();\r\n\t\t\r\n\t\trunning = true;\r\n\t\t//loop while running and the window hasn't received a close command\r\n\t\twhile (running) {\r\n\t\t\ttime = System.nanoTime();\r\n\t\t\t\r\n\t\t\telapsed = (float) ((time-lastCall) / 1e9);\r\n\t\t\tlastCall = time;\r\n\t\t\t\r\n\t\t\taccumulated += elapsed;\r\n\t\t\t\r\n\t\t\twhile (accumulated >= interval) {\r\n\t\t\t\tupdate();\r\n\t\t\t\taccumulated -= interval;\r\n\t\t\t}\r\n\t\t\t//render once per loop, then wait until the render time slot is over before restarting\r\n\t\t\tgame.render();\r\n\t\t\tsync(lastCall/1e9);\r\n\t\t\t\r\n\t\t}\r\n\t\t\r\n\t\t\r\n\t}", "public void speckle() {\n\t\tint r = (height / res) - 1;\n\t\tint c = (width / res);\n\t\tfor (int i = 0; i < c; i++)\t\t{\n\t\t\tint x = rng.nextInt(25);\t\t\t\n\t\t\tif (x == 0) { // 1/25 chance of changing bottom row pixel to black\t \n\t\t\t\tvalues[r][i] = color1;\t\t\t\t\n\t\t\t}\n\t\t\telse if (x == 1) { // 1/25 chance of changing bottom row pixel to white\n\t\t\t\tvalues[r][i] = color2;\n\t\t\t}\n\t\t\t// 23/25 chance of leaving bottom pixel alone\n\t\t}\n\t}", "public void run() {\n scroolViewScanner.setBackgroundColor(Color.TRANSPARENT);\n scroolViewDefect.setBackgroundColor(Color.TRANSPARENT);\n linLayOverView.setBackgroundColor(Color.TRANSPARENT);\n }", "private void reDrawLEDs(){\r\n if (this.isLEDEnable == false) {\r\n for (int i = 1; i < 8; i++) {\r\n LEDs[i].setOff();\t\t\t// turn off all display LEDs\r\n }\r\n }\r\n else {\r\n for (int i = 1; i < 8; i++) {\r\n LEDs[i].setOn(); \r\n LEDs[i].setColor(LEDColor.BLUE);\r\n //Utils.sleep(200);\r\n //leds[i].setOff();\r\n //Utils.sleep(200);\r\n }\r\n }\r\n }", "public void run() {\n if (color != blinkColor && delay > 1) {\n delay--;\n blink(blinkColor);\n } else {\n blink(color);\n if (color != blinkColor) {\n color = blinkColor;\n }\n }\n }", "public void loop(){\n\t}", "@Override\n public void loop() {\n telemetry.addLine(\"DogeCV 2019.1 - Cropping Example\");\n telemetry.update();\n }", "@Override\r\n public void loop() {\r\n //CodeHere\r\n }", "public void loop() {\n\t\tloop(1.0f, 1.0f);\n\t}", "public static void sample() {\n\t\tlcd.clear();\n\t\tint counter =0;\n\t\t//run 100 samples\n\t\twhile(counter<100) {\n\t\t\tmyColorSample.fetchSample(sampleColor, 0); \n\t\t\tfloat r = sampleColor[0]*1000; \n\t\t\tfloat g = sampleColor[1]*1000; \n\t\t\tfloat b = sampleColor[2]*1000; \n\t\t\tSystem.out.print(r +\",\");\n\t\t\tSystem.out.print(g+\",\");\n\t\t\tSystem.out.println(b);\n\t\t\tcounter ++;\n\t\t}\t\t\n\t}", "public void oneSecond() {\r\n int routeSize = connections.size();\r\n if (routeSize != 0) {\r\n // if the signal is green.\r\n if (connections.get(lightIndex).getTrafficLight().getSignal()\r\n == TrafficSignal.GREEN) {\r\n currentGreenTime ++;\r\n if (currentGreenTime + yellowTime == duration) {\r\n connections.get(lightIndex).getTrafficLight().setSignal\r\n (TrafficSignal.YELLOW);\r\n currentGreenTime = 0;\r\n }\r\n }\r\n // if the signal is yellow.\r\n else if (connections.get(lightIndex).getTrafficLight().getSignal()\r\n == TrafficSignal.YELLOW) {\r\n currentYellowTime ++;\r\n if (currentYellowTime == yellowTime) {\r\n connections.get(lightIndex).getTrafficLight().setSignal\r\n (TrafficSignal.RED);\r\n currentYellowTime = 0;\r\n if(lightIndex == connections.size() - 1){\r\n lightIndex = 0;\r\n } else {\r\n lightIndex ++;\r\n }\r\n connections.get(lightIndex).getTrafficLight().setSignal\r\n (TrafficSignal.GREEN);\r\n }\r\n }\r\n }\r\n }", "private void randomiseColors() {\n \t// Give the star a random color for normal circumstances...\n \tcolor.set((float) Random.nextDouble(),\n \t\t\t(float) Random.nextDouble(), (float) Random.nextDouble());\n \n // When the star is twinkling, we draw it twice, once in the color below \n // (not spinning) and then once in the main color defined above.\n twinkleColor.set((float) Random.nextDouble(),\n \t\t(float) Random.nextDouble(), (float) Random.nextDouble());\n }", "public void greenToYellow() {\n\t\tif (StringUtils.isEmpty(this.nextProgram)) {\n\t\t\tthrow new RuntimeException(\n\t\t\t\t\tnew IllegalStateException(\"Method call not allowed as long as nextProgram is not set.\"));\n\t\t}\n\n\t\tString state;\n\t\ttry {\n\t\t\tstate = (String) connection.do_job_get(Trafficlight.getRedYellowGreenState(tls.getId()));\n\t\t} catch (Exception e) {\n\t\t\tthrow new RuntimeException(e);\n\t\t}\n\t\tString newState = JunctionUtil.getRedYellowGreenState(this.tls.getId(), this.nextProgram, 0);\n\n\t\tif (state.length() != newState.length()) {\n\t\t\tthrow new RuntimeException(\"TlsState \" + state + \" and \" + newState + \" need to have the same length!\");\n\t\t}\n\n\t\tchar[] yellowState = state.toCharArray();\n\t\tfor (int i = 0; i < state.length(); i++) {\n\t\t\tchar cCurrent = state.charAt(i);\n\t\t\tchar cNew = newState.charAt(i);\n\n\t\t\tif (cNew == 'r' && (cCurrent == 'G' || cCurrent == 'g')) {\n\t\t\t\tyellowState[i] = 'y';\n\t\t\t}\n\t\t}\n\n\t\ttry {\n\t\t\tconnection.do_job_set(Trafficlight.setRedYellowGreenState(tls.getId(), new String(yellowState)));\n\t\t\tthis.nextProgramScheduledTimestep = ((double) connection.do_job_get(Simulation.getTime()))\n\t\t\t\t\t+ TraasServer.YELLOW_PHASE;\n\t\t} catch (Exception e) {\n\t\t\tthrow new RuntimeException(e);\n\t\t}\n\n\t\tregisterMe();\n\t}", "private void blue(){\n\t\tthis.arretes_fB();\n\t\tthis.coins_fB();\n\t\tthis.coins_a1B();\n\t\tthis.coins_a2B();\n\t\tthis.aretes_aB();\n\t\tthis.cube[22] = \"B\";\n\t}", "public void lightPause() {\n stopPawn.setStyle(\"-fx-background-color: RED;\"\n + \"-fx-background-radius: 30;\"\n + \"-fx-border-radius: 30;\"\n + \"-fx-border-color: 363507;\");\n movePawn.setStyle(\"-fx-background-color: null\");\n buildPawn.setStyle(\"-fx-background-color: null\");\n }", "@Override\n public void run() {\n Message uiMSG;\n //Create message with only SHOW_ORIGINAL_COLOR argument\n uiMSG = BackgroundThread.this.uiHandler.obtainMessage(BidirectionalMessageActivity.SHOW_ORIGINAL_COLOR, 0, 0, null);\n BackgroundThread.this.uiHandler.sendMessage(uiMSG); //Send start message to UI thread\n\n fillProgressbar(progressBar); //Fill progress bar as a long time operation\n //Message with information SHOW_NEW_COLOR as a end of long time operation\n uiMSG = BackgroundThread.this.uiHandler.obtainMessage(BidirectionalMessageActivity.SHOW_NEW_COLOR, 0, 0, null);\n BackgroundThread.this.uiHandler.sendMessage(uiMSG); //Message with end result is sent\n }", "@Override\n public void run() {\n\t\t\t\t\ttable.getDisplay().timerExec(100, new Runnable() {\n\t\t\t\t\t\t@Override\n public void run() {\n//\t\t\t\t\t\t\tfindText.setBackground(PropertyChangeListener.getColor(found == null && matchCount == 0 ? new RGB(255, 0, 0) : new RGB(255, 255, 255)));\n\t\t\t\t\t\t\tif (!wrapped)\n\t\t\t\t\t\t\t\thexEditor.getEditorSite().getActionBars().getStatusLineManager().setMessage(found == null && matchCount == 0 ? Messages.HexEditorControl_7 : matchCount > 0 ? Messages.HexEditorControl_8 + matchCount + Messages.HexEditorControl_9 : null);\n\t\t\t\t\t\t\tupdateStatusPanel();\n\t\t\t\t\t\t}\n\t\t\t\t\t});\n\t\t\t\t}", "private void loopButton(ActionEvent e) {\n if (loop) {\n if (drawPanel.animationDone()) {\n this.tick = 0;\n atTick(this.tick);\n timer.restart();\n }\n }\n }", "@Override\r\n\t\t\tpublic void run() {\n\t\t\t\twhile(true){\r\n\t\t\t\t\tdraw();\r\n\t\t\t\t\t\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t}", "void sendToGreen();", "@Override\n public void loop() throws ConnectionLostException {\n for (int i = 0; i < 32; i++) {\n tempRGB_.clear();\n if (Math.random() < frequency_) {\n getRandomColor(tempRGB_);\n }\n setLed(i, tempRGB_);\n }\n // Since SPI messages are limited to 64 bytes, and we need to send\n // 96 bytes, we divide the message into two chunks of 48. We assume\n // that the SPI clock is slow enough (50K) so that the second half\n // will finish being sent to the IOIO before the first half\n // finished transmission.\n try {\n ioio_.beginBatch();\n spi_.writeReadAsync(0, buffer1_, buffer1_.length,\n buffer1_.length, null, 0);\n spi_.writeRead(buffer2_, buffer2_.length, buffer2_.length,\n null, 0);\n ioio_.endBatch();\n Thread.sleep(50);\n } catch (InterruptedException ignored) {\n }\n }", "protected void onCycle() {\n\n }", "public void cycle(){\r\n \r\n \r\n if(collision()){\r\n endtime = 1;\r\n animator.stop();\r\n }else{\r\n if(max_h == false)\r\n ch.v--;\r\n if(ch.v == 150)\r\n max_h = true;\r\n\r\n if(max_h == true & ch.v <= 330){\r\n ch.v++;\r\n if(ch.v == 330){\r\n done = true;\r\n \r\n }\r\n }\r\n }\r\n }", "@Override\n\tpublic void green() {\n\t\tSystem.out.println(\"Green Light\");\n\t}", "@Override\r\n\t\tpublic void run() {\n\t\t\twhile(true){\r\n\t\t\t\t\r\n\t\t\t}\r\n\t\t}", "static void fillWithRandomColors() {\n\n for ( int row = 0; row < ROWS; row++ ) {\n for ( int column = 0; column < COLUMNS; column++ ) {\n changeToRandomColor( row, column );\n }\n }\n }", "protected void runEachDay() {\n \n }", "public void run() {\r\n\t\t\tfor (int k = 0; k < 5; k++) {\r\n\t\t\t\t// System.out.println(\"\"+k);\r\n\t\t\t\ttry {\r\n\t\t\t\t\tThread.sleep(1000);\r\n\t\t\t\t} catch (InterruptedException ie) {\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\tfor (int i = 0; i <= 4; i++) {\r\n\t\t\t\tfor (int j = 0; j < 1000000; j++) {\r\n\t\t\t\t}\r\n\t\t\t\tsetStep((int) Math.pow(2, i) - 1);\r\n\t\t\t\t// enabled = i;\r\n\t\t\t\trepaint();\r\n\t\t\t\ttry {\r\n\t\t\t\t\tThread.sleep(1000);\r\n\t\t\t\t} catch (InterruptedException ie) {\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t\t// System.out.println(\"ENDE\");\r\n\t\t}", "@Override\r\n\tpublic void run() {\n\t\twhile(true){\r\n\t\t\trepaint();\r\n\t\t\ttry {\r\n\t\t\t\tThread.sleep(2000);\r\n\t\t\t} catch (InterruptedException e) {\r\n\t\t\t\t// TODO Auto-generated catch block\r\n\t\t\t\te.printStackTrace();\r\n\t\t\t}\r\n\t\t}\r\n\t}", "@Override\n public void loop() {\n switch (auto) {\n\n //Time Function Socks\n case 0:\n if (runtime.milliseconds() <= 6250) {\n robot.hook.setPower(1.0);\n } else if (runtime.milliseconds() > 6250) {\n robot.hook.setPower(0);\n auto++;\n } else {\n robot.hook.setPower(0);\n auto++;\n }\n\n break;\n\n case 1 :\n runtime.reset();\n auto++;\n break;\n\n\n case 2:\n if (runtime.milliseconds() <= 1000) {\n robot.drive(MovementEnum.RIGHTSTRAFE, 0.5);\n }\n else if(runtime.milliseconds() > 1000) {\n robot.drive(MovementEnum.STOP, 0.0);\n auto++;\n }\n else {robot.drive(MovementEnum.STOP, 0.0);\n auto++;\n }\n break;\n\n case 3:\n runtime.reset();\n auto++;\n break;\n\n case 4:\n // if (runtime.milliseconds() >= 12000) {\n //enable for color sensor here using DogeCV or OpenCV (Preferably DogeCV)\n /*\n if (runtime.milliseconds() > 7000) {\n robot.drive(MovementEnum.RIGHTTURN, 0.65);\n }\n auto++;\n */\n if (runtime.milliseconds() <= 3000) {\n robot.drive(MovementEnum.BACKWARD, 1);\n }\n else if(runtime.milliseconds() > 3000){ robot.drive(MovementEnum.STOP,0);}\n else {robot.drive(MovementEnum.STOP,0);}\n // auto++;\n\n\n break;\n\n case 34:\n if (runtime.milliseconds() <= 10000) {\n robot.drive(MovementEnum.BACKWARD, 1);\n }\n else if(runtime.milliseconds() > 10000)\n // auto++;\n break;\n\n case 45:\n if (runtime.milliseconds() > 11000) {\n robot.claw.setPosition(1);\n }\n auto++;\n break;\n\n case 5:\n if (runtime.milliseconds() > 13000) {\n robot.drive(MovementEnum.BACKWARD, 1);\n }\n break;\n\n default: {\n robot.drive(MovementEnum.STOP, 0);\n\n }\n break;\n //if gold color (RGB value) is detected return value. G\n // Go forward, go backwards, and turn left.\n // Go forward until distance to wall is 6 inches.\n // Turn 45 degrees, and go forward.\n // Drop the team marker, then back up into the crater.\n }\n\n }", "@Override\n\tpublic void Red() {\n\t\tSystem.out.println(\"Red Light\");\n\t\t\n\t}", "@Override\n\tpublic void color() {\n\t\tSystem.out.println(\"Colour is red\");\n\t\t\n\t}", "private void loop() {\n try {\n while (true) {\n for (int i = 0; i < projectNames.length; i++) {\n final HudsonProjectStatus status = ciServer.extractElement(projectNames[i]);\n LOG.debug(\"About to tell device about status \" + status);\n switch (status.getStatus()) {\n case SUCCESS:\n if (status.getActivity() == HudsonActivity.BUILDING) {\n buildLight.bldBlink(i, 0, 0, buildLight.bldGetMaxColor());\n } else {\n buildLight.bldSolid(i, 0, 0, buildLight.bldGetMaxColor());\n }\n break;\n case FAILURE:\n if (status.getActivity() == HudsonActivity.BUILDING) {\n buildLight.bldBlink(i, buildLight.bldGetMaxColor(), 0, 0);\n } else {\n buildLight.bldSolid(i, buildLight.bldGetMaxColor(), 0, 0);\n }\n break;\n case EXCEPTION:\n case UNKNOWN:\n default:\n buildLight.bldBlink(i, buildLight.bldGetMaxColor(), buildLight\n .bldGetMaxColor(), 0);\n break;\n }\n }\n // 1/4 of hudson server polling rate so we're never more than 1/4 interval behind\n Thread.sleep(SERVER_POLLING_INTERVAL / 4 * 1000);\n }\n } catch (final InterruptedException e) {\n // assume we're done\n }\n }", "private void updateImage() {\r\n \tfor(int i=0;i<rows;i++){\r\n for(int j=0;j<cols;j++){\r\n if(complexArray[i][j].escapeTime(RADIUS, maxIterations)!=-1){//the complex escaped\r\n mandelbrotColor[i][j]=new RGBColor(palette[complexArray[i][j].escapeTime(RADIUS, maxIterations)]);\r\n }\r\n else{\r\n mandelbrotColor[i][j]=palette[complexArray[i][j].escapeTime(RADIUS, maxIterations)+1];//the complex didnt escaped\r\n }\r\n }\r\n }\r\n }", "private void update() {\n\t\tColor fColor = fgColorProvider.getCurrentColor();\n\t\tColor bColor = bgColorProvider.getCurrentColor();\n\t\tsetText(String.format(\"Foreground color: (%d, %d, %d), background color: (%d, %d, %d).\", \n\t\t\t\tfColor.getRed(), fColor.getGreen(), fColor.getBlue(),\n\t\t\t\tbColor.getRed(), bColor.getGreen(), bColor.getBlue()));\n\t}", "public void cycleDay() {\r\n player.gametick();\r\n }", "@Override\r\n public void init_loop() {\r\n }", "@Override\r\n public void init_loop() {\r\n }", "@Override\n\t\t\tpublic void run() {\n\t\t\t\t\n\t\t\t}", "@Override\n\t\t\tpublic void run() {\n\t\t\t\t\n\t\t\t}", "public void run() {\r\n\t\tboolean repeat = true;\r\n\t\tint count = 0;\r\n\t\twhile(repeat){\r\n\t\t\tcount ++;\r\n\t\t\t//updates currency rates every hour (count>60)\r\n\t\t\tif(count > 60){\r\n\t\t\t\tcurrencies.updateRates();\r\n\t\t\t\tcount = 1;\r\n\t\t\t}\r\n\t\t\tprintStatus();\r\n\t\t\ttry{\r\n\t\t\t\tThread.sleep(60000);\r\n\t\t\t}catch(InterruptedException ex){\r\n\t\t\t\trepeat = false;\r\n\t\t\t}\r\n\t\t}\r\n\t}", "@Override\n\t\t\tpublic void run() {\n\t\t\t\trunOnUiThread(new Runnable() {\n\t\t\t\t\t@Override\n\t\t\t\t\tpublic void run() {\n\t\t\t\t\t\tif(isRecognition) {\n\t\t\t\t\t\t\talpha *= 0.95f;\n//\t\t\t\t\t\t\tsetBackgroundColor((int) (255 * (1 - label) * alpha));\n\t\t\t\t\t\t\ttxtHandParts.setTextColor(Color.argb((int) (alpha * 255), 255,\n\t\t\t\t\t\t\t\t\t255, 255));\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(alpha > 0.1f) {\n\t\t\t\t\t\t\t\tLog.d(LOGTAG, (int) (255 * (1 - label) * alpha)+\"\");\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t\n\t\t\t\t\t}\n\t\t\t\t});\n\t\t\t}", "public void blink(){\r\n boolean p = false;\r\n for (int i=1; i<=5; i++){\r\n buzzer(p); \r\n p = !p;\r\n try {\r\n Thread.sleep(500);\r\n } catch (InterruptedException ex) {\r\n ex.printStackTrace();\r\n }\r\n }\r\n }", "@Override\r\n\tpublic void runn() {\n\t\t\r\n\t}", "public SimpleColorLoop(double time, int...colors)\r\n\t{\r\n\t\tif(time <= 0)\r\n\t\t\ttime = 1000;\r\n\t\t\r\n\t\tdelay_between_colors = time;\r\n\t\t\r\n\t\tthis.colors = colors;\r\n\t}", "public void run() {\n \tdisposeColor(errorColor);\n \tdisposeColor(inputColor);\n \tdisposeColor(messageColor); \t\n \tdisposeColor(bkgColor); \t\n \tRGB errorRGB = PreferenceConverter.getColor(CUIPlugin.getDefault().getPreferenceStore(), BuildConsolePreferencePage.PREF_BUILDCONSOLE_ERROR_COLOR);\n \tRGB inputRGB = PreferenceConverter.getColor(CUIPlugin.getDefault().getPreferenceStore(), BuildConsolePreferencePage.PREF_BUILDCONSOLE_OUTPUT_COLOR);\n \tRGB messageRGB = PreferenceConverter.getColor(CUIPlugin.getDefault().getPreferenceStore(), BuildConsolePreferencePage.PREF_BUILDCONSOLE_INFO_COLOR);\n \tRGB bkgRGB = PreferenceConverter.getColor(CUIPlugin.getDefault().getPreferenceStore(), BuildConsolePreferencePage.PREF_BUILDCONSOLE_BACKGROUND_COLOR); \t\n \terrorColor = new Color(d, errorRGB);\n \tinputColor = new Color(d, inputRGB);\n \tmessageColor = new Color(d, messageRGB);\n \tbkgColor = new Color(d, bkgRGB);\n error.setColor(errorColor);\n input.setColor(inputColor);\n message.setColor(messageColor);\n console.setBackground(bkgColor);\n }", "@Override\n\tpublic void run() {\n\t\twhile(true) {\n\t\t\t//休眠1s\n\t\t\ttry {\n\t\t\t\tThread.sleep(500);\n\t\t\t} catch (InterruptedException e) {\n\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\ttimes++;\n\t\t\tthis.repaint();\n\t\t}\n\t}", "public void checkGreen() {\n boolean is = true;\n outerloop:\n for (int i = 0; i < 4; i++) {\n for (int j = 0; j < 4; j++) {\n if (buttColor[i][j].equals(\"red\")) {\n is = false;\n break outerloop;\n }\n }\n }\n\n if (is) {\n\n TextView tv = (TextView) findViewById(R.id.counter);\n tv.setTextColor(Color.GREEN);\n //counter = 0;\n if (counter >= 0) {\n if (selectedlanguage.equals(\"eng\")) {\n Toast.makeText(this, \"You did it :)\", Toast.LENGTH_SHORT).show();\n Toast.makeText(this, \"Shake for next level..)\", Toast.LENGTH_SHORT).show();\n restart.setText(\"MENU\");\n }\n else if (selectedlanguage.equals(\"svk\")){\n Toast.makeText(this, \"Podarilo sa ti to :)\", Toast.LENGTH_SHORT).show();\n Toast.makeText(this, \"Potrasenim pokracujes..\", Toast.LENGTH_SHORT).show();\n restart.setText(\"MENU\");\n }\n else {\n Toast.makeText(this, \"Du hast es geschafft :)\", Toast.LENGTH_SHORT).show();\n Toast.makeText(this, \"Sie zittern weiter..\", Toast.LENGTH_SHORT).show();\n restart.setText(\"MENU\");\n }\n Bitmap bitmap = BitmapFactory.decodeResource(getResources(), R.drawable.bulb);\n View view = findViewById(R.id.mylayout);\n view.setBackground(new BitmapDrawable(bitmap));\n\n restNext = true;\n }\n else\n {\n //restart.setText(\"MENU\");\n\n if (selectedlanguage.equals(\"eng\"))\n Toast.makeText(getApplicationContext(), \"Almost :/ (steps gone)\", Toast.LENGTH_SHORT).show();\n else if (selectedlanguage.equals(\"svk\"))\n Toast.makeText(getApplicationContext(), \"Skoro :/ (mimo krokov)\", Toast.LENGTH_SHORT).show();\n else\n Toast.makeText(getApplicationContext(), \"Fast: / (Schritte weg)\", Toast.LENGTH_SHORT).show();\n Bitmap bitmap = BitmapFactory.decodeResource(getResources(), R.drawable.broken);\n View view = findViewById(R.id.mylayout);\n view.setBackground(new BitmapDrawable(bitmap));\n }\n }\n }", "public void infectfirstpixel() {\r\n randompixel = r.nextInt(100);\r\n pixellist.get(randompixel).setBackground(Color.red);\r\n count++;\r\n storage.add(randompixel);\r\n\r\n }", "@Override\r\n\t\t\tpublic void run() {\n\t\t\t\t\r\n\t\t\t}", "@Override\r\n\t\t\tpublic void run() {\n\t\t\t\t\r\n\t\t\t}", "public void run(double deltaMs) {\n //wave360.setPeriod(speedParam.getValuef() * speedMult);\n //wave100.setPeriod(speedParam.getValuef() * speedMult);\n total_ms1+=deltaMs;\n total_ms2+=deltaMs;\n // Use a for loop here to set the ube colors\n if (total_ms2>50) {\n\t for (int i=0; i<model.baseCubes.size(); i++ ) {\n\t\t BaseCube cube=model.baseCubes.get(i);\n\n\t\t if (hits_cube(i,current_cube_r)) {\n\t\t\t shadow[i][0]=(float)1;\n\t\t\t shadow[i][1]=(float)0;\n\t\t\t shadow[i][2]=(float)0;\n\t\t } else if (hits_cube(i,current_cube_g)) {\n\t\t\t shadow[i][0]=(float)0;\n\t\t\t shadow[i][1]=(float)1;\n\t\t\t shadow[i][2]=(float)0;\n\t\t } else if (hits_cube(i,current_cube_b)) {\n\t\t\t shadow[i][0]=(float)0;\n\t\t\t shadow[i][1]=(float)0;\n\t\t\t shadow[i][2]=(float)1;\n\t\t } else {\n\t\t\t shadow[i][0]=(float)Math.min(1,new_shadow(shadow[i][0],dmax(i,current_cube_r)));\n\t\t\t shadow[i][1]=(float)Math.min(1,new_shadow(shadow[i][1],dmax(i,current_cube_g)));\n\t\t\t shadow[i][2]=(float)Math.min(1,new_shadow(shadow[i][2],dmax(i,current_cube_b)));\n\t\t }\n\t\t float norm =shadow[i][0]*2+shadow[i][1]+shadow[i][2];\n\t\t float h = (360*shadow[i][0]*2+120*shadow[i][1]+240*shadow[i][2])/norm;\n\t\t float v = (shadow[i][0]+shadow[i][1]+shadow[i][2])*100;\n\t\t colors[cube.index] = lx.hsb( h , 100, Math.min(100,v));\n\t }\n\t\ttotal_ms2=0;\n }\n if (total_ms1>10*speedParam.getValuef()) {\n\n\t //transistion to new cube\n\n\t float new_p;\n\t for (int j=0; j<n; j++) {\n\t\t new_p = (float)Math.random();\n\t\t for (int i=0; i<model.baseCubes.size(); i++) {\n\t\t\t if (new_p>0.0) {\n\t\t\t\t new_p-=p[current_cube_r[j]][i];\n\t\t\t } else {\n\t\t\t\t current_cube_r[j]=i;\n\t\t\t\t break;\n\t\t\t }\n\t\t }\n\t\t new_p = (float)Math.random();\n\t\t for (int i=0; i<model.baseCubes.size(); i++) {\n\t\t\t if (new_p>0.0) {\n\t\t\t\t new_p-=p[current_cube_g[j]][i];\n\t\t\t } else {\n\t\t\t\t current_cube_g[j]=i;\n\t\t\t\t break;\n\t\t\t }\n\t\t }\n\t\t new_p = (float)Math.random();\n\t\t for (int i=0; i<model.baseCubes.size(); i++) {\n\t\t\t if (new_p>0.0) {\n\t\t\t\t new_p-=p[current_cube_b[j]][i];\n\t\t\t } else {\n\t\t\t\t current_cube_b[j]=i;\n\t\t\t\t break;\n\t\t\t }\n\t\t }\n\t }\n\t total_ms1=0;\n }\n }", "@Override\n public void execute() {\n Color currentColor = m_colorWheel.getColor();\n String currentColorString = m_colorWheel.getColorString(currentColor); \n if(currentColorString == \"Unknown\"){\n end(false);\n }\n if(seesNewColor == false && currentColorString != initialColorString) {\n seesNewColor = true;\n }\n if(seesNewColor == true &&currentColorString == initialColorString) {\n rotationCount += 1;\n seesNewColor = false;\n System.out.println(\"Current rotation count: \" + rotationCount);\n\n }\n if(rotationCount == 6) {\n m_colorWheel.wheelSpinStop();\n System.out.println(\"Stopping ColorWheel motor\");\n isDone = true;\n }\n }", "@Override\r\n public void run() {\n for (int i = 0; i < item.getDevices().size(); i++) {\r\n write(parseRGBCmd(msAccessColor(color)), 0, 0, item.getDevices().get(i).getSocket(), item.getDevices().get(i).getBos());\r\n }\r\n runCommand = true;\r\n }", "private void doGameCycle() {\n update();\n repaint();\n }", "public void run() {\n mEmoteButton.setBackgroundResource(R.drawable.button_yellow);\n mIsEmotePlayable = true;\n\n }", "public void restart(){\n\t\tfor(int i =1; i<26;i++){\t\t\t\t\t\t\t//Die Anfangsfarbe wird eingestellt. Wenn man auf \"restart\" klickt, wird eine zufällig große Anzahl von Buttons rot gefärbt. \n\t\t\tp.getButton(i).setBackground(Color.white);\t\t\n\t\t}\n\t\tfor(int i = 1; i <(int)(Math.random()*26); i++){\n\t\t\tp.getButton((int)(Math.random()*26)).setBackground(Color.red);}\n\t}", "static void start() {\n if( flag == 1 ) return;\n for( Tile x : tiles ) {\n if( x.getBackground() == cyan ) x.setBackground(white);\n }\n Thread fill = new Thread(new FloodFill());\n fill.start();\n flag = 1;\n }", "@Override\n public void run() {\n while (true) {\n long currentTime = System.nanoTime();\n\n draw();\n check(currentTime);\n }\n }", "public static void update(){\n\t\t\n\t\tgraphFrame.setColor(color);\n\t}", "public void cycle() {\n\t\tshiftWaterConcentration();\r\n\t\tshiftHeat();\r\n\t\tshiftStatus();\r\n\t\tburn();\r\n\t\tif (goldilocksCheck()) goldilocksTime++;\r\n\t\telse goldilocksTime--;\r\n\t\tif (goldilocksTime < 0) goldilocksTime = 0;\r\n\t\tlifeformCycles();\r\n\t\tif (toGrass()) {\r\n\t\t\tTile t = new Grass(r, c, waterConcentration, heat, lifeforms);\r\n\t\t\tWorld.setTile(r, c, t);\r\n\t\t}\r\n\t}", "private void loop() {\n\t\tif ( this.useRandomAddr()) {\n\t\t\tthis.changeBTAddress();\n\t\t}\n\t\n\t\t\n\t\t// schedule the BeaconOnTask which will then start the beacon cycle.\n\t\tthis.beaconTimer = new Timer();\n\t\tBeaconOn beaconOnTask = new BeaconOn( this);\t\t\n\t\tthis.beaconTimer.schedule( beaconOnTask, 0);\n\t\t\t\t\n\t\t// a periodic task to indicate change of BT address and renewal of proximity ID.\n\t\t// the interval is 10 minutes which if scheduling were real-time should cause distinct\n\t\t// ENINs to be used in proximity ID generation.\n\t\tthis.rollingProximityGenerationTimer = new Timer();\t\n\t\tTimerTask indicatorTask = new RollingProximityGenerationIndicator( this);\t\n\t\t\n\t\t// (task, delay in milli-seconds, period in milli-seconds). note that we are not scheduling on ENIN boundaries...\t\t\n\t\tthis.rollingProximityGenerationTimer.scheduleAtFixedRate( indicatorTask, ROLLING_PROXIMITY_INTERVAL, ROLLING_PROXIMITY_INTERVAL);\n\t\n\t}", "private void blink() {\r\n\r\n\t\t_timer = new Timer(50, new TimerListener());\r\n\t\t_timer.start();\r\n\r\n\r\n\t}", "@Override\n\tpublic void run() {\n\t\twhile(true){\n\t\t\t\n\t\t}\n\t}", "public void fillColor() {\n\t\tSystem.out.println(\"Blue color\");\n\t}", "protected synchronized void updateColorAnimation() {\n synchronized (getViewController()) {\n if (colorStateTime < COLOR_ANIMATION_DURATION) {\n colorStateTime += Gdx.graphics.getDeltaTime();\n if (isColorAnimationFinished()) {\n getViewController().notifyAll();\n }\n }\n }\n }", "private void updateLight() {\r\n\t}", "public void sleep()\r\n\t{\r\n\t\tif (regulate)\r\n\t\t{\r\n\t\t\tDisplay.sync(fps);\r\n\t\t}\r\n\t}", "@Override\r\n\t\tpublic void run() {\n\t\t\twhile(running) {\r\n\t\t\t\trepaint();\r\n\t\t\t\ttry {\r\n\t\t\t\t\tThread.sleep(100);\r\n\t\t\t\t}catch (InterruptedException e) {\r\n\t\t\t\t\te.printStackTrace();\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t}", "@Override\n public void periodic() {\n\n }" ]
[ "0.7265129", "0.6882044", "0.67436546", "0.6629186", "0.65546054", "0.64549243", "0.6407474", "0.6397444", "0.63712573", "0.6357339", "0.6356455", "0.63360244", "0.63273245", "0.6314445", "0.6294025", "0.6291781", "0.6279386", "0.6263594", "0.62631744", "0.6259403", "0.6254352", "0.6254352", "0.62447166", "0.62214094", "0.6204301", "0.62029886", "0.6187939", "0.6174122", "0.6161566", "0.6145267", "0.6135795", "0.61285645", "0.61191463", "0.60814923", "0.6078774", "0.60610175", "0.6045922", "0.602803", "0.6022409", "0.60175747", "0.6009822", "0.59942085", "0.59939575", "0.59846514", "0.5966519", "0.5950444", "0.5947578", "0.594498", "0.594213", "0.59418213", "0.5941661", "0.5940885", "0.5925558", "0.59251016", "0.59242994", "0.59227264", "0.5918908", "0.5917531", "0.59101945", "0.59052", "0.5904482", "0.58935153", "0.58933616", "0.58775365", "0.5870884", "0.58701724", "0.5861584", "0.5857555", "0.5857555", "0.5849543", "0.5849543", "0.5843861", "0.58387667", "0.58307725", "0.5828023", "0.58218414", "0.5821793", "0.58214504", "0.5819511", "0.5817349", "0.58167654", "0.58167654", "0.5816184", "0.58138174", "0.5812389", "0.5808786", "0.5806805", "0.58050025", "0.5797314", "0.57952046", "0.57897294", "0.5788488", "0.5784261", "0.5780878", "0.57740206", "0.5773573", "0.5773077", "0.5771139", "0.57676035", "0.57674795", "0.5767117" ]
0.0
-1
/ Code to run when the op mode is first disabled goes here
@Override public void stop() { }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void runOpMode() {\n servo0 = hardwareMap.servo.get(\"servo0\");\n servo1 = hardwareMap.servo.get(\"servo1\");\n digital0 = hardwareMap.digitalChannel.get(\"digital0\");\n motor0 = hardwareMap.dcMotor.get(\"motor0\");\n motor1 = hardwareMap.dcMotor.get(\"motor1\");\n motor0B = hardwareMap.dcMotor.get(\"motor0B\");\n motor2 = hardwareMap.dcMotor.get(\"motor2\");\n blinkin = hardwareMap.get(RevBlinkinLedDriver.class, \"blinkin\");\n motor3 = hardwareMap.dcMotor.get(\"motor3\");\n park_assist = hardwareMap.dcMotor.get(\"motor3B\");\n\n if (digital0.getState()) {\n int_done = true;\n } else {\n int_done = false;\n }\n motor_stuff();\n waitForStart();\n if (opModeIsActive()) {\n while (opModeIsActive()) {\n lancher_position();\n slow_mode();\n drive_robot();\n foundation_grabber(1);\n launcher_drive();\n data_out();\n Pickingupblockled();\n lettingoutblockled();\n Forwardled();\n backwardled();\n Turnleftled();\n Turnrightled();\n Stationaryled();\n }\n }\n }", "@Override\n public abstract void runOpMode();", "@Override\n public void runOpMode() {\n initialize();\n\n //wait for user to press start\n waitForStart();\n\n if (opModeIsActive()) {\n\n // drive forward 24\"\n // turn left 90 degrees\n // turnLeft(90);\n // drive forward 20\"\n // driveForward(20);\n // turn right 90 degrees\n // turnRight(90);\n // drive forward 36\"\n // driveForward(36);\n\n }\n\n\n }", "@Override\n public void runOpMode() {\n motorFL = hardwareMap.get(DcMotor.class, \"motorFL\");\n motorBL = hardwareMap.get(DcMotor.class, \"motorBL\");\n motorFR = hardwareMap.get(DcMotor.class, \"motorFR\");\n motorBR = hardwareMap.get(DcMotor.class, \"motorBR\");\n landerRiser = hardwareMap.get(DcMotor.class, \"lander riser\");\n landerRiser = hardwareMap.get(DcMotor.class, \"lander riser\");\n landerRiser.setDirection(DcMotor.Direction.FORWARD);\n landerRiser.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n markerDrop = hardwareMap.get(Servo.class, \"marker\");\n markerDrop.setDirection(Servo.Direction.FORWARD);\n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update();\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n runtime.reset();\n\n //Landing & unlatching\n landerRiser.setPower(-1);\n telemetry.addData(\"Status\", \"Descending\");\n telemetry.update();\n sleep(5550);\n landerRiser.setPower(0);\n telemetry.addData(\"Status\",\"Unhooking\");\n telemetry.update();\n move(-0.5, 600, true);\n strafe(-0.4,0.6, 3600, true);\n move(0.5,600,true);\n markerDrop.setPosition(0);\n sleep(1000);\n markerDrop.setPosition(0.5);\n sleep(700);\n markerDrop.setPosition(0);\n strafe(0, -0.5,500,true);\n strafe(0.5, -0.25, 8500, true);\n\n }", "@Override\n public void resetDeviceConfigurationForOpMode() {\n\n }", "@Override\n public void runOpMode() {\n\n robot.init(hardwareMap);\n robot.MotorRightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.MotorLeftFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.MotorRightFront.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n robot.MotorLeftFront.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n /** Wait for the game to begin */\n while (!isStarted()) {\n telemetry.addData(\"angle\", \"0\");\n telemetry.update();\n }\n\n\n }", "@Override\n public void runOpMode() {\n commands.init(hardwareMap);\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n // run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n sleep(30000);\n }\n }", "public void runOpMode() {\n robot.init(hardwareMap);\n\n // Send telemetry message to signify robot waiting;\n telemetry.addData(\"Status\", \"Resetting Encoders\"); //\n telemetry.update();\n\n robot.leftMotor.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n robot.rightMotor.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n idle();\n\n robot.leftMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n robot.rightMotor.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n // Send telemetry message to indicate successful Encoder reset\n telemetry.addData(\"Path0\", \"Starting at %7d :%7d\",\n robot.leftMotor.getCurrentPosition(),\n robot.rightMotor.getCurrentPosition());\n telemetry.addData(\"Gyro Heading:\", \"%.4f\", getHeading());\n telemetry.update();\n\n int cameraMonitorViewId = hardwareMap.appContext.getResources().getIdentifier(\"cameraMonitorViewId\", \"id\", hardwareMap.appContext.getPackageName());\n\n VuforiaLocalizer.Parameters parameters = new VuforiaLocalizer.Parameters(cameraMonitorViewId);\n\n parameters.vuforiaLicenseKey = \"Adiq0Gb/////AAAAme76+E2WhUFamptVVqcYOs8rfAWw8b48caeMVM89dEw04s+/mRV9TqcNvLkSArWax6t5dAy9ISStJNcnGfxwxfoHQIRwFTqw9i8eNoRrlu+8X2oPIAh5RKOZZnGNM6zNOveXjb2bu8yJTQ1cMCdiydnQ/Vh1mSlku+cAsNlmfcL0b69Mt2K4AsBiBppIesOQ3JDcS3g60JeaW9p+VepTG1pLPazmeBTBBGVx471G7sYfkTO0c/W6hyw61qmR+y7GJwn/ECMmXZhhHkNJCmJQy3tgAeJMdKHp62RJqYg5ZLW0FsIh7cOPRkNjpC0GmMCMn8AbtfadVZDwn+MPiF02ZbthQN1N+NEUtURP0BWB1CmA\";\n\n\n parameters.cameraDirection = VuforiaLocalizer.CameraDirection.FRONT;\n this.vuforia = ClassFactory.createVuforiaLocalizer(parameters);\n\n VuforiaTrackables relicTrackables = this.vuforia.loadTrackablesFromAsset(\"RelicVuMark\");\n VuforiaTrackable relicTemplate = relicTrackables.get(0);\n relicTemplate.setName(\"relicVuMarkTemplate\"); // can help in debugging; otherwise not necessary\n\n telemetry.addData(\">\", \"Press Play to start\");\n telemetry.update();\n\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n relicTrackables.activate();\n\n //while (opModeIsActive()) {\n\n /**\n * See if any of the instances of {@link relicTemplate} are currently visible.\n * {@link RelicRecoveryVuMark} is an enum which can have the following values:\n * UNKNOWN, LEFT, CENTER, and RIGHT. When a VuMark is visible, something other than\n * UNKNOWN will be returned by {@link RelicRecoveryVuMark#from(VuforiaTrackable)}.\n */\n RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.from(relicTemplate);\n while (vuMark == RelicRecoveryVuMark.UNKNOWN) {\n vuMark = RelicRecoveryVuMark.from(relicTemplate);\n /* Found an instance of the template. In the actual game, you will probably\n * loop until this condition occurs, then move on to act accordingly depending\n * on which VuMark was visible. */\n }\n telemetry.addData(\"VuMark\", \"%s visible\", vuMark);\n telemetry.update();\n sleep(550);\n\n //switch (vuMark) {\n // case LEFT: //RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.LEFT;\n // coLumn = 2;\n // case CENTER:// RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.CENTER;\n // coLumn = 1;\n // case RIGHT:// RelicRecoveryVuMark vuMark = RelicRecoveryVuMark.RIGHT;\n // coLumn = 0;\n //}\n if ( vuMark == RelicRecoveryVuMark.LEFT) {\n coLumn = 2;\n }\n else if(vuMark == RelicRecoveryVuMark.RIGHT){\n coLumn = 0;\n }\n else if(vuMark == RelicRecoveryVuMark.CENTER){\n coLumn = 1;\n }\n\n\n telemetry.addData(\"coLumn\", \"%s visible\", coLumn);\n telemetry.update();\n sleep(550);\n\n\n\n//if jewej is red 1 if jewel is blue 2\n\n // if(jewel == 1) {\n // gyroturn(-10, TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //gyroturn(-2, -TURN_SPEED, TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //}\n //else if(jewel == 2){\n // gyroturn(10, -TURN_SPEED, TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n // gyroturn(-2, TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n //}\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[0][coLumn], disandTurn[0][coLumn], 5.0); // S1: Forward 24 Inches with 5 Sec timeout shoot ball\n\n gyroturn(disandTurn[1][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[0], -turndistance[0], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[2][coLumn], disandTurn[2][coLumn], 5.0); // S3: Forward 43.3 iNCHES\n\n gyroturn(disandTurn[3][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[4][coLumn], disandTurn[4][coLumn], 5.0);// S5: Forward 12 Inches with 4 Sec timeout\n\n gyroturn(disandTurn[5][coLumn], TURN_SPEED, -TURN_SPEED); //encoderDrive(TURN_SPEED, TURN_SPEED, turndistance[1], -turndistance[1], 5.0);\n\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[6][coLumn], disandTurn[6][coLumn], 5.0);// S5: Forward 12 Inches with 4 Sec timeout\n\n\n Outake();\n encoderDrive(DRIVE_SPEED, DRIVE_SPEED, disandTurn[7][coLumn], disandTurn[7][coLumn], 5.0);// S6: Forward 48 inches with 4 Sec timeout\n }", "@Override\n public void runOpMode() {\n RobotMain main = new RobotMain(this,hardwareMap,telemetry);\n\n //initialize controls\n imuTeleOpDualGamepad control = new imuTeleOpDualGamepad(main,gamepad1,gamepad2);\n\n waitForStart();\n\n //Pull the tail back from autonomous\n main.JewelArm.setServo(.65);\n\n //Continually run the control program in the algorithm\n while (opModeIsActive()) control.run();\n }", "@Override\n public void runOpMode () {\n motor1 = hardwareMap.get(DcMotor.class, \"motor1\");\n motor2 = hardwareMap.get(DcMotor.class, \"motor2\");\n\n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update();\n //Wait for game to start (driver presses PLAY)\n waitForStart();\n\n /*\n the overridden runOpMode method happens with every OpMode using the LinearOpMode type.\n hardwareMap is an object that references the hardware listed above (private variables).\n The hardwareMap.get method matches the name of the device used in the configuration, so\n we would have to change the names (ex. motorTest to Motor 1 or Motor 2 (or something else))\n if not, the opMode won't recognize the device\n\n in the second half of this section, it uses something called telemetry. In the first and\n second lines it sends a message to the driver station saying (\"Status\", \"Initialized\") and\n then it prompts the driver to press start and waits. All linear functions should have a wait\n for start command so that the robot doesn't start executing the commands before the driver\n wants to (or pushes the start button)\n */\n\n //run until end of match (driver presses STOP)\n double tgtpower = 0;\n while (opModeIsActive()) {\n telemetry.addData(\"Left Stick X\", this.gamepad1.left_stick_x);\n telemetry.addData(\"Left Stick Y\", this.gamepad1.left_stick_y);\n telemetry.addData(\"Right Stick X\", this.gamepad1.right_stick_x);\n telemetry.addData(\"Right Stick Y\", this.gamepad1.right_stick_y);\n if (this.gamepad1.left_stick_y < 0){\n tgtpower=-this.gamepad1.left_stick_y;\n motor1.setPower(tgtpower);\n motor2.setPower(-tgtpower);\n }else if (this.gamepad1.left_stick_y > 0){\n tgtpower=this.gamepad1.left_stick_y;\n motor1.setPower(-tgtpower);\n motor2.setPower(tgtpower);\n }else if (this.gamepad1.left_stick_x > 0){\n tgtpower=this.gamepad1.left_stick_x;\n motor1.setPower(tgtpower);\n motor2.setPower(tgtpower);\n }else if (this.gamepad1.left_stick_x < 0){\n tgtpower=-this.gamepad1.left_stick_x;\n motor1.setPower(-tgtpower);\n motor2.setPower(-tgtpower);\n }else{\n motor1.setPower(0);\n motor2.setPower(0);\n }\n telemetry.addData(\"Motor1 Power\", motor1.getPower());\n telemetry.addData(\"Motor2 Power\", motor2.getPower());\n telemetry.addData(\"Status\", \"Running\");\n telemetry.update ();\n\n\n /*\n if (this.gamepad1.right_stick_x == 1){\n //trying to make robot turn right, == 1 may be wrong\n motor2.setPower(-1);\n }\n else if (this.gamepad1.right_stick_x == -1){\n //trying to make robot turn left, == -1 may be wrong\n motor1.setPower(-1);\n }\n else {\n\n }\n */\n\n\n /*\n After the driver presses start,the opMode enters a while loop until the driver presses stop,\n while the loop is running it will continue to send messages of (\"Status\", \"Running\") to the\n driver station\n */\n\n\n }\n }", "@Override\n\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update();\n\n // Initialize the hardware variables. Note that the strings used here as parameters\n // to 'get' must correspond to the names assigned during the robot configuration\n // step (using the FTC Robot Controller app on the phone).\n // FR = hardwareMap.get(DcMotor.class, \"FR\");\n // FL = hardwareMap.get(DcMotor.class, \"FL\");\n // BR = hardwareMap.get(DcMotor.class, \"BR\");\n //BL = hardwareMap.get(DcMotor.class, \"BL\");\n //yoo are ___\n // Most robots need the motor on one side to be reversed to drive forward\n // Reverse the motor that runs backwards when connected directly to the battery\n/* FR.setDirection(DcMotor.Direction.FORWARD);\n FL.setDirection(DcMotor.Direction.REVERSE);\n BR.setDirection(DcMotor.Direction.FORWARD);\n BL.setDirection(DcMotor.Direction.REVERSE);\n\n */ RevBlinkinLedDriver blinkinLedDriver;\n RevBlinkinLedDriver.BlinkinPattern pattern;\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n blinkinLedDriver = this.hardwareMap.get(RevBlinkinLedDriver.class, \"PrettyBoi\");\n blinkinLedDriver.setPattern(RevBlinkinLedDriver.BlinkinPattern.RAINBOW_WITH_GLITTER);\n// runtime.reset();\n\n // run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n\n\n\n // Show the elapsed game time and wheel power.\n// telemetry.addData(\"Status\", \"Run Time: \" + runtime.toString());\n// // telemetry.addData(\"Motors\", \"FL (%.2f), FR (%.2f), BL (%.2f), BR (%.2f)\", v1, v2, v3, v4);\n// telemetry.update();\n }\n }", "@Override \n public void runOpMode() \n {\n leftMotors = hardwareMap.get(DcMotor.class, \"left_Motors\");\n rightMotors = hardwareMap.get(DcMotor.class, \"right_Motors\");\n vLiftMotor = hardwareMap.get(DcMotor.class, \"vLift_Motor\"); \n \n leftMotors.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n rightMotors.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n leftMotors.setDirection(DcMotor.Direction.REVERSE);\n rightMotors.setDirection(DcMotor.Direction.FORWARD);\n vLiftMotor.setDirection(DcMotor.Direction.REVERSE);\n vLiftMotor.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n \n waitForStart(); //press play button, actives opMode\n intakePivotServo.setPosition(intakePivotServoPos);\n while (opModeIsActive()) \n { \n drive();\n pivotIntake();\n pivotLift();\n \n }//opModeIsActive \n \n }", "@Override\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Initializing. Please Wait...\");\n telemetry.update();\n\n\n //Use the Teleop initialization method\n testPaddle = hardwareMap.get(CRServo.class, \"servoPaddle\");\n\n //Tell drivers that initializing is now complete\n telemetry.setAutoClear(true);\n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update();\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n runtime.reset();\n\n // run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n telemetry.addData(\"Status\", \"Run Time: \" + runtime.toString());\n\n testPaddle.setPower(0.80);\n\n telemetry.update();\n\n }\n\n }", "@Override\n public void runOpMode() {\n float strafeRight;\n float strafeLeft;\n\n frontRight = hardwareMap.dcMotor.get(\"frontRight\");\n backRight = hardwareMap.dcMotor.get(\"backRight\");\n frontLeft = hardwareMap.dcMotor.get(\"frontLeft\");\n backLeft = hardwareMap.dcMotor.get(\"backLeft\");\n flipper = hardwareMap.crservo.get(\"flipper\");\n\n // Put initialization blocks here.\n frontRight.setDirection(DcMotorSimple.Direction.REVERSE);\n backRight.setDirection(DcMotorSimple.Direction.REVERSE);\n waitForStart();\n while (opModeIsActive()) {\n // Power to drive\n frontRight.setPower(gamepad1.right_stick_y * 0.5);\n frontRight.setPower(gamepad1.right_stick_y * 0.75);\n backRight.setPower(gamepad1.right_stick_y * 0.75);\n frontLeft.setPower(gamepad1.left_stick_y * 0.75);\n backLeft.setPower(gamepad1.left_stick_y * 0.75);\n flipper.setPower(gamepad2.left_stick_y);\n // Strafing code\n strafeRight = gamepad1.right_trigger;\n strafeLeft = gamepad1.left_trigger;\n if (strafeRight != 0) {\n frontLeft.setPower(-(strafeRight * 0.8));\n frontRight.setPower(strafeRight * 0.8);\n backLeft.setPower(strafeRight * 0.8);\n backRight.setPower(-(strafeRight * 0.8));\n } else if (strafeLeft != 0) {\n frontLeft.setPower(strafeLeft * 0.8);\n frontRight.setPower(-(strafeLeft * 0.8));\n backLeft.setPower(-(strafeLeft * 0.8));\n backRight.setPower(strafeLeft * 0.8);\n }\n // Creep\n if (gamepad1.dpad_up) {\n frontRight.setPower(-0.4);\n backRight.setPower(-0.4);\n frontLeft.setPower(-0.4);\n backLeft.setPower(-0.4);\n } else if (gamepad1.dpad_down) {\n frontRight.setPower(0.4);\n backRight.setPower(0.4);\n frontLeft.setPower(0.4);\n backLeft.setPower(0.4);\n } else if (gamepad1.dpad_right) {\n frontRight.setPower(-0.4);\n backRight.setPower(-0.4);\n } else if (gamepad1.dpad_left) {\n frontLeft.setPower(-0.4);\n backLeft.setPower(-0.4);\n }\n if (gamepad1.x) {\n frontLeft.setPower(1);\n backLeft.setPower(1);\n frontRight.setPower(1);\n backRight.setPower(1);\n sleep(200);\n frontRight.setPower(1);\n backRight.setPower(1);\n frontLeft.setPower(-1);\n backLeft.setPower(-1);\n sleep(700);\n }\n telemetry.update();\n }\n }", "@Override\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Resetting Encoders\"); //\n telemetry.update();\n\n leftFront = hardwareMap.get(DcMotor.class, \"left_front\");\n rightFront = hardwareMap.get(DcMotor.class, \"right_front\");\n leftBack = hardwareMap.get(DcMotor.class, \"left_back\");\n rightBack = hardwareMap.get(DcMotor.class, \"right_back\");\n\n\n leftFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n rightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n leftBack.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n rightFront.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n\n right = hardwareMap.get(Servo.class, \"right\");\n left = hardwareMap.get(Servo.class, \"left\");\n // Most robots need the motor on one side to be reversed to drive forward\n // Reverse the motor that runs backwards when connected directly to the battery\n leftFront.setDirection(DcMotor.Direction.REVERSE);\n rightFront.setDirection(DcMotor.Direction.FORWARD);\n leftBack.setDirection(DcMotor.Direction.REVERSE);\n rightBack.setDirection(DcMotor.Direction.FORWARD);\n\n leftFront.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n leftBack.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n rightFront.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n rightBack.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n digitalTouch = hardwareMap.get(DigitalChannel.class, \"sensor_digital\");\n digitalTouch.setMode(DigitalChannel.Mode.INPUT);\n\n right.setDirection(Servo.Direction.REVERSE);\n\n right.scaleRange(0, 0.25);\n left.scaleRange(0.7, 1);\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n\n servo(0);\n runtime.reset();\n encoderSideways(0.25, -5, -5, 5);\n // drive until touch sensor pressed\n // activate servos to grab platform\n // drive backwards for a while\n // release servos\n // sideways part\n // remember to do red autonomous for repackage org.firstinspires.ftc.teamcode;\n }", "@Override\n public void runOpMode() {\n hw = new RobotHardware(robotName, hardwareMap);\n rd = new RobotDrive(hw);\n rs=new RobotSense(hw, telemetry);\n /*rd.moveDist(RobotDrive.Direction.FORWARD, .5, .3);\n rd.moveDist(RobotDrive.Direction.REVERSE, .5, .3);\n rd.moveDist(RobotDrive.Direction.FORWARD, .5, 1);\n rd.moveDist(RobotDrive.Direction.REVERSE, .5, 1);*/\n telemetry.addData(\"Ready! \", \"Go Flamangos!\"); \n telemetry.update();\n\n //Starting the servos in the correct starting position\n /*hw.armRight.setPosition(1-.3);\n hw.armLeft.setPosition(.3);\n hw.level.setPosition(.3+.05);*/\n hw.f_servoLeft.setPosition(1);\n hw.f_servoRight.setPosition(0.5);\n \n rd.moveArm(hw.startPos());\n waitForStart();\n while (opModeIsActive()) {\n \n /*Starting close to the bridge on the building side\n Move under the bridge and push into the wall*/\n rd.moveDist(RobotDrive.Direction.LEFT,2,.5);\n rd.moveDist(RobotDrive.Direction.FORWARD, 10, .5);\n break;\n }\n }", "@Override\n public void runOpMode() {\n try {\n leftfrontDrive = hardwareMap.get(DcMotor.class, \"frontLeft\");\n leftfrontDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n rightfrontDrive = hardwareMap.get(DcMotor.class, \"frontRight\");\n rightfrontDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n leftbackDrive = hardwareMap.get(DcMotor.class, \"backLeft\");\n leftbackDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n leftbackDrive.setDirection(DcMotor.Direction.REVERSE);\n\n rightbackDrive = hardwareMap.get(DcMotor.class, \"backRight\");\n rightbackDrive.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n lift = hardwareMap.get(DcMotor.class, \"Lift\");\n lift.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n lift.setDirection(DcMotor.Direction.REVERSE);\n\n markerArm = hardwareMap.get(Servo.class, \"markerArm\");\n\n armActivator = hardwareMap.get(DcMotor.class, \"armActivator\");\n armActivator.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\n\n } catch (IllegalArgumentException iax) {\n bDebug = true;\n }\n\n BNO055IMU.Parameters parameters = new BNO055IMU.Parameters();\n parameters.angleUnit = BNO055IMU.AngleUnit.DEGREES;\n parameters.accelUnit = BNO055IMU.AccelUnit.METERS_PERSEC_PERSEC;\n parameters.calibrationDataFile = \"BNO055IMUCalibration.json\";\n parameters.loggingEnabled = true;\n parameters.loggingTag = \"IMU\";\n parameters.accelerationIntegrationAlgorithm = new JustLoggingAccelerationIntegrator();\n\n imu = hardwareMap.get(BNO055IMU.class, \"imu\");\n imu.initialize(parameters);\n\n waitForStart(); //the rest of the code begins after the play button is pressed\n\n sleep(3000);\n\n drive(0.35, 0.5);\n\n turn(90.0f);\n\n drive(1.8, 0.5);\n\n turn(45.0f);\n\n drive(2.5, -0.5);\n\n sleep(1000);\n\n markerArm.setPosition(1);\n\n sleep(1000);\n\n markerArm.setPosition(0);\n\n sleep(1000);\n\n drive(2.5,.75);\n\n turn(179.0f);\n\n drive(1.5, 1.0);\n\n requestOpModeStop(); //end of autonomous\n }", "@Override\n public void runOpMode() {\n detector = new modifiedGoldDetector(); //Create detector\n detector.init(hardwareMap.appContext, CameraViewDisplay.getInstance(), DogeCV.CameraMode.BACK); //Initialize it with the app context and camera\n detector.enable(); //Start the detector\n\n //Initialize the drivetrain\n motorFL = hardwareMap.get(DcMotor.class, \"motorFL\");\n motorFR = hardwareMap.get(DcMotor.class, \"motorFR\");\n motorRL = hardwareMap.get(DcMotor.class, \"motorRL\");\n motorRR = hardwareMap.get(DcMotor.class, \"motorRR\");\n motorFL.setDirection(DcMotor.Direction.REVERSE);\n motorFR.setDirection(DcMotor.Direction.FORWARD);\n motorRL.setDirection(DcMotor.Direction.REVERSE);\n motorRR.setDirection(DcMotor.Direction.FORWARD);\n\n //Reset encoders\n motorFL.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorFR.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorRL.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorRR.setMode(DcMotor.RunMode.STOP_AND_RESET_ENCODER);\n motorFL.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorFR.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorRL.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n motorRR.setMode(DcMotor.RunMode.RUN_USING_ENCODER);\n\n telemetry.addData(\"IsFound: \", detector.isFound());\n telemetry.addData(\">\", \"Waiting for start\");\n telemetry.update();\n\n\n //TODO Pass skystone location to storage\n\n //Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n /**\n * *****************\n * OpMode Begins Here\n * *****************\n */\n\n //Disable the detector\n if(detector != null) detector.disable();\n\n //Start the odometry processing thread\n odometryPositionUpdate positionUpdate = new odometryPositionUpdate(motorFL, motorFR, motorRL, motorRR, inchPerCount, trackWidth, wheelBase, 75);\n Thread odometryThread = new Thread(positionUpdate);\n odometryThread.start();\n runtime.reset();\n\n //Run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n\n absPosnX = startPosnX + positionUpdate.returnOdometryX();\n absPosnY = startPosnY + positionUpdate.returnOdometryY();\n absPosnTheta = startPosnTheta + positionUpdate.returnOdometryTheta();\n\n telemetry.addData(\"X Position [in]\", absPosnX);\n telemetry.addData(\"Y Position [in]\", absPosnY);\n telemetry.addData(\"Orientation [deg]\", absPosnTheta);\n telemetry.addData(\"Thread Active\", odometryThread.isAlive());\n telemetry.update();\n\n//Debug: Drive forward for 3.0 seconds and make sure telemetry is correct\n if (runtime.seconds() < 3.0) {\n motorFL.setPower(0.25);\n motorFR.setPower(0.25);\n motorRL.setPower(0.25);\n motorRR.setPower(0.25);\n }else {\n motorFL.setPower(0);\n motorFR.setPower(0);\n motorRL.setPower(0);\n motorRR.setPower(0);\n }\n\n\n }\n //Stop the odometry processing thread\n odometryThread.interrupt();\n }", "public void runOpMode() {\n leftBackDrive = hardwareMap.get(DcMotor.class, \"left_back_drive\"); //port 0, hub1\n rightBackDrive = hardwareMap.get(DcMotor.class, \"right_back_drive\"); //port 1, hub1\n leftFrontDrive = hardwareMap.get(DcMotor.class, \"left_front_drive\"); //port 2, hub1\n rightFrontDrive = hardwareMap.get(DcMotor.class, \"right_front_drive\"); //port 3, hub1\n craneExtend = hardwareMap.get(DcMotor.class, \"craneExtend\"); //port 0, hub2\n cranePitch = hardwareMap.get(DcMotor.class, \"cranePitch\"); //port 1, hub2\n craneElevate = hardwareMap.get(DcMotor.class, \"craneElevate\"); //port 2, hub2\n fakeMotor = hardwareMap.get(DcMotor.class, \"fakeMotor\"); //port 2, hub3\n craneGrab = hardwareMap.get(Servo.class, \"craneGrab\"); //port 0, servo\n craneGrabAttitude = hardwareMap.get(Servo.class, \"craneGrabAttitude\"); //port 2, servo\n trayGrab = hardwareMap.get(Servo.class, \"trayGrab\"); //port 1, servo\n flipperLeft = hardwareMap.get(Servo.class, \"flipperLeft\"); //port 3. servo\n flipperRight = hardwareMap.get(Servo.class, \"flipperRight\"); //port 4, servo\n \n //Setting the motor directions\n leftBackDrive.setDirection(DcMotor.Direction.FORWARD);\n rightBackDrive.setDirection(DcMotor.Direction.REVERSE);\n leftFrontDrive.setDirection(DcMotor.Direction.FORWARD);\n rightFrontDrive.setDirection(DcMotor.Direction.REVERSE);\n\n //Initializing variables\n \n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update(); //Done initalizing\n\n //Wait for the game to start (driver presses PLAY)\n waitForStart();\n runtime.reset();\n\n //run until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n \n//******************************************************************************\n\n //Drive controls\n if (gamepad1.left_trigger>0 || gamepad1.right_trigger>0) { //Crab\n leftBackDrive.setPower(gamepad1.left_stick_x*0.8);\n rightBackDrive.setPower(-gamepad1.left_stick_x*0.8);\n leftFrontDrive.setPower(-gamepad1.left_stick_x*0.8);\n rightFrontDrive.setPower(gamepad1.left_stick_x*0.8);\n }\n\n else { //Tank\n leftBackDrive.setPower(-gamepad1.left_stick_x);\n rightBackDrive.setPower(-gamepad1.right_stick_x);\n leftFrontDrive.setPower(-gamepad1.left_stick_x);\n rightFrontDrive.setPower(-gamepad1.right_stick_x);\n }\n }\n \n//******************************************************************************\n\n //Crane control\n \n \n//******************************************************************************\n\n //Telemetry display\n telemetry.addData(\"Run Time:\", \"\" + runtime.toString());\n telemetry.addData(\"Motor Power\", \"L (%.2f), R (%.2f)\", gamepad1.left_stick_y, gamepad1.right_stick_y);\n telemetry.update();\n }", "void disable(final Op op);", "void enable(final Op op);", "@Override\n public void runOpMode() {\n leftDrive = hardwareMap.get(DcMotor.class, \"left_drive\");\n rightDrive = hardwareMap.get(DcMotor.class, \"right_drive\");\n intake = hardwareMap.get (DcMotor.class, \"intake\");\n dropServo = hardwareMap.get(Servo.class, \"drop_Servo\");\n leftDrive.setDirection(DcMotor.Direction.REVERSE);\n rightDrive.setDirection(DcMotor.Direction.FORWARD);\n\n dropServo.setPosition(1.0);\n waitForStart();\n dropServo.setPosition(0.6);\n sleep(500);\n VuforiaOrientator();\n encoderSequence(\"dumbDrive\");\n\n\n }", "void setBasicMode() {basicMode = true;}", "void enableMod();", "public int evalMode(int op, int mode) {\n if (mode == 4) {\n return this.state <= AppOpsManager.resolveFirstUnrestrictedUidState(op) ? 0 : 1;\n }\n return mode;\n }", "@Override\r\n public void runOpMode() {\n robot.init(hardwareMap);\r\n\r\n telemetry.addData(\"Status\", \"Initialized\");\r\n telemetry.update();\r\n\r\n //Wait for the Pressing of the Start Button\r\n waitForStart();\r\n\r\n // run until the end of the match (driver presses STOP)\r\n while (opModeIsActive()) {\r\n\r\n motorSpeed[0] = driveSpeed(gamepad1.left_stick_x, gamepad1.left_stick_y, gamepad2.left_stick_x)[0];\r\n motorSpeed[1] = driveSpeed(gamepad1.left_stick_x, gamepad1.left_stick_y, gamepad2.left_stick_x)[1];\r\n motorSpeed[2] = driveSpeed(gamepad1.left_stick_x, gamepad1.left_stick_y, gamepad2.left_stick_x)[2];\r\n motorSpeed[3] = driveSpeed(gamepad1.left_stick_x, gamepad1.left_stick_y, gamepad2.left_stick_x)[3];\r\n\r\n robot.drive1.setPower(motorSpeed[0]);\r\n robot.drive1.setPower(motorSpeed[1]);\r\n robot.drive1.setPower(motorSpeed[2]);\r\n robot.drive1.setPower(motorSpeed[3]);\r\n\r\n telemetry.addData(\"Drive 1 Speed\", motorSpeed[0]);\r\n telemetry.addData(\"Drive 2 Speed\", motorSpeed[1]);\r\n telemetry.addData(\"Drive 3 Speed\", motorSpeed[2]);\r\n telemetry.addData(\"Drive 4 Speed\", motorSpeed[3]);\r\n telemetry.update();\r\n\r\n }\r\n }", "public void enable() {\n operating = true;\n }", "public void mode() {\n APIlib.getInstance().addJSLine(jsBase + \".mode();\");\n }", "@Override\n public void runOpMode() {\n RobotOmniWheels5 myRobot = new RobotOmniWheels5(hardwareMap);\n\n // Put initialization blocks here.\n waitForStart();\n\n //code will continue to run until you hit stop in the app\n while(opModeIsActive()) {\n\n double leftStickYValue = gamepad1.left_stick_y;\n if (leftStickYValue < -.1) {\n //Set the robotspeed to the stick value\n //As Stick Y value is negative when pressed up, use negative in front\n myRobot.setRobotSpeed(-leftStickYValue);\n myRobot.move();\n } else {\n if (leftStickYValue > .1){\n //Set the robotspeed to the stick value\n //As Stick Y value is positive when pressed down, use negative in front to move back\n myRobot.setRobotSpeed(-leftStickYValue);\n myRobot.move();\n }\n else {\n myRobot.stopMoving();\n }\n }\n }\n }", "public abstract void initMode();", "default void onEnable() {}", "@Override\n public void runOpMode() {\n telemetry.addData(\"Status\", \"Simple Ready to run\"); //\n telemetry.update();\n telemetry.addData(\"Status\", \"Initialized\");\n\n /**\n * Initializes the library functions\n * Robot hardware and motor functions\n */\n robot = new Robot_1617(hardwareMap);\n motorFunctions = new MotorFunctions(-1, 1, 0, 1, .05);\n\n //servo wheels are flipped in configuration file\n robot.servoLeftWheel.setPosition(.45);\n robot.servoRightWheel.setPosition(.25);\n\n robot.servoLeftArm.setPosition(0);\n robot.servoRightArm.setPosition(0.7);\n\n robot.servoFlyAngle.setPosition(1);\n\n robot.servoElbow.setPosition(0.95);\n robot.servoShoulder.setPosition(0.1);\n\n robot.servoFeed.setPosition(.498);\n\n robot.servoPlaid.setPosition(.85);\n\n telemetry.addData(\"Servos: \", \"Initialized\");\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n sleep(5000);\n robot.motorLift.setPower(0);\n robot.servoFlyAngle.setPosition(0);\n sleep(500);\n robot.motorFlyLeft.setPower(.9);\n robot.motorFlyRight.setPower(1);\n sleep(250);\n robot.motorIntakeElevator.setPower(1);\n robot.servoFeed.setPosition(-1);\n telemetry.addData(\"Status\", \"Shooting\"); //\n telemetry.update();\n sleep(5000);\n robot.motorFlyLeft.setPower(0);\n robot.motorFlyRight.setPower(0);\n// sleep(5000); //no idea why this is here\n robot.motorIntakeElevator.setPower(0);\n robot.servoFeed.setPosition(.1);\n sleep(250);\n\n telemetry.addData(\"Status\", \"Driving\");\n telemetry.update();\n encoderDrive(1.0, 30, 30, 1);\n\n encoderDrive(1.0, 35, 35, 1);\n }", "@Override\r\n public void runOpMode() {\n\r\n mtrFL = hardwareMap.dcMotor.get(\"fl_drive\");\r\n mtrFR = hardwareMap.dcMotor.get(\"fr_drive\");\r\n mtrBL = hardwareMap.dcMotor.get(\"bl_drive\");\r\n mtrBR = hardwareMap.dcMotor.get(\"br_drive\");\r\n\r\n\r\n // Set directions for motors.\r\n mtrFL.setDirection(DcMotor.Direction.REVERSE);\r\n mtrFR.setDirection(DcMotor.Direction.FORWARD);\r\n mtrBL.setDirection(DcMotor.Direction.REVERSE);\r\n mtrBR.setDirection(DcMotor.Direction.FORWARD);\r\n\r\n\r\n //zero power behavior\r\n mtrFL.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\r\n mtrFR.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\r\n mtrBL.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\r\n mtrBR.setZeroPowerBehavior(DcMotor.ZeroPowerBehavior.BRAKE);\r\n\r\n\r\n // Set power for all motors.\r\n mtrFL.setPower(powFL);\r\n mtrFR.setPower(powFR);\r\n mtrBL.setPower(powBL);\r\n mtrBR.setPower(powBR);\r\n\r\n\r\n // Set all motors to run with given mode\r\n mtrFL.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\r\n mtrFR.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\r\n mtrBL.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\r\n mtrBR.setMode(DcMotor.RunMode.RUN_WITHOUT_ENCODER);\r\n\r\n waitForStart();\r\n\r\n // run until the end of the match (driver presses STOP)\r\n while (opModeIsActive()) {\r\n g1ch2 = -gamepad1.left_stick_y;\r\n g1ch3 = gamepad1.right_stick_x;\r\n g2ch2 = -gamepad2.left_stick_x;\r\n g2ch4 = -gamepad2.right_stick_x;\r\n g2left = gamepad2.left_trigger;\r\n g2right = gamepad2.right_trigger;\r\n\r\n\r\n powFL = Range.clip(g1ch2 + g1ch3, -1, 1);\r\n powFR = Range.clip(g1ch2 - g1ch3, -1, 1);\r\n powBL = Range.clip(g1ch2 + g1ch3, -1, 1);\r\n powBR = Range.clip(g1ch2 - g1ch3, -1, 1);\r\n\r\n\r\n mtrFL.setPower(powFL);\r\n mtrFR.setPower(powFR);\r\n mtrBL.setPower(powBL);\r\n mtrBR.setPower(powBR);\r\n sleep(50);\r\n }\r\n }", "@Override //when init is pressed\n public void runOpMode(){\n robot.initMotors(hardwareMap);\n robot.initServos(hardwareMap);\n robot.useEncoders(false);\n\n waitForStart();\n runtime.reset();\n\n double speedSet = 5;//robot starts with speed 5 due to 40 ratio motors being op\n double reduction = 7.5;//fine rotation for precise stacking. higher value = slower rotation using triggers\n double maxPower = 0;\n\n boolean forks = false;\n\n while (opModeIsActive()) {\n double LX = gamepad1.left_stick_x, LY = gamepad1.left_stick_y, rotate = gamepad1.right_stick_x;\n\n //bumpers set speed of robot\n if(gamepad1.right_bumper)\n speedSet += 0.0005;\n else if(gamepad1.left_bumper)\n speedSet -= 0.0005;\n\n speedSet = Range.clip(speedSet, 1, 10);//makes sure speed is limited at 10.\n\n if(!gamepad1.right_bumper && !gamepad1.left_bumper)//makes sure speed does not round every refresh. otherwise, speed won't be able to change\n speedSet = Math.round(speedSet);\n\n if(gamepad1.a) {\n forks = !forks;\n sleep(50);\n }\n\n if(forks) {\n robot.setForks(DOWN);\n }\n else if(earthIsFlat) {\n robot.setForks(UP);\n }\n\n //Holonomic Vector Math\n robot.drive(LX, LY, rotate);\n\n telemetry.addData(\"Drive\", \"Holonomic\");\n\n if(forks)\n telemetry.addData(\"Forks\", \"DOWN\");\n else\n telemetry.addData(\"Forks\", \"UP\");\n\n telemetry.addData(\"speedSet\", \"%.2f\", speedSet);\n telemetry.update();\n }\n }", "public void changeMode() {\n methodMode = !methodMode;\n }", "@Override\n public void runOpMode() {\n ringShooterMotor1 = hardwareMap.get(DcMotorEx.class, \"ringShooterMotor1\");\n ringShooterMotor2 = hardwareMap.get(DcMotorEx.class, \"ringShooterMotor2\");\n ringFeederServo = hardwareMap.get(Servo.class, \"ringFeederServo\");\n ringFeederServo.setPosition(0.6); // sets initial position of servo\n\n\n // Wait for the game to start (driver presses PLAY)\n waitForStart();\n\n // runs until the end of the match (driver presses STOP)\n while (opModeIsActive()) {\n\n // here: add telemetry to see motor velocity if you want\n telemetry.addData(\"ring motor velocity\", ringShooterMotor1.getVelocity());\n telemetry.update();\n\n\n // Press right trigger for ring feeder servo\n if (gamepad2.right_trigger == 1) {\n// if (ringShooterMotor1.getVelocity() <= powerShootMotorVelocity){\n ringFeederServo.setPosition(1);\n sleep(300);\n ringFeederServo.setPosition(0.6);\n// }\n }\n\n // press Y for shooter motor for tower goal\n if (gamepad2.y) {\n ringShooterMotor1.setVelocity(towerGoalMotorVelocity);\n ringShooterMotor2.setVelocity(towerGoalMotorVelocity);\n\n }\n\n // press X for shooter motor for powershot\n if (gamepad2.x) {\n ringShooterMotor1.setVelocity(powerShootMotorVelocity);\n ringShooterMotor2.setVelocity(powerShootMotorVelocity);\n\n }\n }\n }", "public static void start(LinearOpMode opMode) {\n }", "public void switchInsMode() {\n this.inputMode = !this.inputMode;\n }", "@Override\n public void runOpMode(){\n motors[0][0] = hardwareMap.dcMotor.get(\"frontLeft\");\n motors[0][1] = hardwareMap.dcMotor.get(\"frontRight\");\n motors[1][0] = hardwareMap.dcMotor.get(\"backLeft\");\n motors[1][1] = hardwareMap.dcMotor.get(\"backRight\");\n // The motors on the left side of the robot need to be in reverse mode\n for(DcMotor[] motor : motors){\n motor[0].setDirection(DcMotor.Direction.REVERSE);\n }\n // Being explicit never hurt anyone, right?\n for(DcMotor[] motor : motors){\n motor[1].setDirection(DcMotor.Direction.FORWARD);\n }\n\n waitForStart();\n\n //Kill ten seconds\n runtime.reset();\n while(runtime.seconds()<10); runtime.reset();\n\n while(runtime.milliseconds()<700){\n // Loop through front and back motors\n for(DcMotor[] motor : motors){\n // Set left motor power\n motor[0].setPower(100);\n // Set right motor power\n motor[1].setPower(100);\n }\n }\n\n while(runtime.milliseconds()<200){\n // Loop through front and back motors\n for(DcMotor[] motor : motors){\n // Set left motor power\n motor[0].setPower(-100);\n // Set right motor power\n motor[1].setPower(-100);\n }\n }\n\n runtime.reset();\n // Loop through front and back motors\n for(DcMotor[] motor : motors){\n // Set left motor power\n motor[0].setPower(0);\n // Set right motor power\n motor[1].setPower(0);\n }\n }", "public void disable() {\n operating = false;\n }", "@Override\n public void runOpMode() {\n androidGyroscope = new AndroidGyroscope();\n\n // Put initialization blocks here.\n if (androidGyroscope.isAvailable()) {\n telemetry.addData(\"Status\", \"GyroAvailable\");\n }\n waitForStart();\n if (opModeIsActive()) {\n // Put run blocks here.\n androidGyroscope.startListening();\n androidGyroscope.setAngleUnit(AngleUnit.DEGREES);\n while (opModeIsActive()) {\n telemetry.addData(\"X Axis\", androidGyroscope.getX());\n telemetry.update();\n }\n }\n }", "@DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2014-03-25 14:14:32.594 -0400\", hash_original_method = \"45C4A93D9DB00E5177EB1AA33C0FC790\", hash_generated_method = \"A67AFB0821ABBDFC1442B7AD04AF9F51\")\n \n public static boolean setPowerModeCommand(int mode){\n \tdouble taintDouble = 0;\n \ttaintDouble += mode;\n \n \treturn ((taintDouble) == 1);\n }", "@Override\r\n public void runOpMode() throws InterruptedException{\r\n //hardwareMapPrint();\r\n //telemetry.addData(\"Status\", \"Started\");\r\n //telemetry.update();\r\n //sleep(10000);\r\n //robot.setUp();\r\n //telemetry.addData(\"Status\", \"initialized\");\r\n //telemetry.update();\r\n setUp(hardwareMap, telemetry);\r\n waitForStart();\r\n\r\n while(opModeIsActive()){\r\n telemetry.addData(\"distance\", robot.ultrasonicSensor.getDistance(DistanceUnit.INCH));\r\n telemetry.update();\r\n }\r\n }", "public void setOp(boolean value) {}", "void disableMod();", "@Override\n public void runOpMode() throws InterruptedException {\n leftfMotor = hardwareMap.dcMotor.get(\"m0\");\n rightfMotor = hardwareMap.dcMotor.get(\"m1\");\n leftbMotor = hardwareMap.dcMotor.get(\"m2\");\n rightbMotor = hardwareMap.dcMotor.get(\"m3\");\n rPMotor = hardwareMap.dcMotor.get(\"rPMotor\");\n leftClamp = hardwareMap.servo.get(\"left_servo\");\n rightClamp = hardwareMap.servo.get(\"right_servo\");\n rightfMotor.setDirection(DcMotor.Direction.REVERSE);\n rightbMotor.setDirection(DcMotor.Direction.REVERSE);\n\n telemetry.addData(\"Mode\", \"waiting\");\n telemetry.update();\n\n // wait for start button.\n\n\n waitForStart();\n\n leftY = 0;\n rightY = 0;\n leftZ = 0;\n rightZ = 0;\n bumperL = false;\n bumperR = false;\n\n while (opModeIsActive()) {\n\n telemetry.addData(\"left stick y \", gamepad1.left_stick_y);\n telemetry.update();\n leftY = -gamepad1.left_stick_y;\n\n rightY = -gamepad1.right_stick_y;\n\n leftZ = gamepad1.left_trigger;\n rightZ = gamepad1.right_trigger;\n\n bumperL = gamepad1.left_bumper;\n bumperR = gamepad1.right_bumper;\n\n\n leftfMotor.setPower(leftY);\n leftbMotor.setPower(leftY);\n rightfMotor.setPower(rightY);\n rightbMotor.setPower(rightY);\n\n\n if (leftZ > 0) {\n rPMotor.setPower(leftZ/10);\n\n } else if (rightZ > 0) {\n rPMotor.setPower(-rightZ/10);\n\n }\n\n\n telemetry.addData(\"Mode\", \"running\");\n telemetry.addData(\"sticks\", \" left=\" + leftY + \" right=\" + rightY);\n telemetry.addData(\"trig\", \" left=\" + leftZ + \" right=\" + rightZ);\n telemetry.update();\n\n\n if (bumperL) {\n\n clampMove += .01;\n leftClamp.setPosition(-clampMove);\n rightClamp.setPosition(clampMove);\n\n } else if (bumperR) {\n\n clampMove -= .01;\n leftClamp.setPosition(-clampMove);\n rightClamp.setPosition(clampMove);\n\n }\n\n idle();\n\n\n }\n }", "@Override\n public void runOpMode() {\n frontLeftWheel = hardwareMap.dcMotor.get(\"frontLeft\");\n backRightWheel = hardwareMap.dcMotor.get(\"backRight\");\n frontRightWheel = hardwareMap.dcMotor.get(\"frontRight\");\n backLeftWheel = hardwareMap.dcMotor.get(\"backLeft\");\n\n //telemetry sends data to robot controller\n telemetry.addData(\"Output\", \"hardwareMapped\");\n\n // The TFObjectDetector uses the camera frames from the VuforiaLocalizer, so we create that\n // first.\n initVuforia();\n\n if (ClassFactory.getInstance().canCreateTFObjectDetector()) {\n initTfod();\n } else {\n telemetry.addData(\"Sorry!\", \"This device is not compatible with TFOD\");\n }\n\n /**\n * Activate TensorFlow Object Detection before we wait for the start command.\n * Do it here so that the Camera Stream window will have the TensorFlow annotations visible.\n **/\n if (tfod != null) {\n tfod.activate();\n }\n\n /** Wait for the game to begin */\n telemetry.addData(\">\", \"Press Play to start op mode\");\n telemetry.update();\n waitForStart();\n\n if (opModeIsActive()) {\n while (opModeIsActive()) {\n if (tfod != null) {\n // getUpdatedRecognitions() will return null if no new information is available since\n // the last time that call was made\n List<Recognition> updatedRecognitions = tfod.getUpdatedRecognitions();\n if(updatedRecognitions == null) {\n frontLeftWheel.setPower(0);\n frontRightWheel.setPower(0);\n backLeftWheel.setPower(0);\n backRightWheel.setPower(0);\n } else if (updatedRecognitions != null) {\n telemetry.addData(\"# Object Detected\", updatedRecognitions.size());\n // step through the list of recognitions and display boundary info.\n int i = 0;\n\n\n for (Recognition recognition : updatedRecognitions) {\n float imageHeight = recognition.getImageHeight();\n float blockHeight = recognition.getHeight();\n\n //-----------------------\n// stoneCX = (recognition.getRight() + recognition.getLeft())/2;//get center X of stone\n// screenCX = recognition.getImageWidth()/2; // get center X of the Image\n// telemetry.addData(\"screenCX\", screenCX);\n// telemetry.addData(\"stoneCX\", stoneCX);\n// telemetry.addData(\"width\", recognition.getImageWidth());\n //------------------------\n\n telemetry.addData(\"blockHeight\", blockHeight);\n telemetry.addData(\"imageHeight\", imageHeight);\n telemetry.addData(String.format(\"label (%d)\", i), recognition.getLabel());\n telemetry.addData(String.format(\" left,top (%d)\", i), \"%.03f , %.03f\", recognition.getLeft(), recognition.getTop());\n telemetry.addData(String.format(\" right,bottom (%d)\", i), \"%.03f , %.03f\", recognition.getRight(), recognition.getBottom());\n\n\n if(hasStrafed == false) {\n float midpoint = (recognition.getLeft() + recognition.getRight()) /2;\n float multiplier ;\n if(midpoint > 500) {\n multiplier = -(((int)midpoint - 500) / 100) - 1;\n log = \"Adjusting Right\";\n sleep(200);\n } else if(midpoint < 300) {\n multiplier = 1 + ((500 - midpoint) / 100);\n log = \"Adjusting Left\";\n sleep(200);\n } else {\n multiplier = 0;\n log = \"In acceptable range\";\n hasStrafed = true;\n }\n frontLeftWheel.setPower(-0.1 * multiplier);\n backLeftWheel.setPower(0.1 * multiplier);\n frontRightWheel.setPower(-0.1 * multiplier);\n backRightWheel.setPower(0.1 * multiplier);\n } else {\n if( blockHeight/ imageHeight < .5) {\n frontLeftWheel.setPower(-.3);\n backLeftWheel.setPower(.3);\n frontRightWheel.setPower(.3);\n backRightWheel.setPower(-.3);\n telemetry.addData(\"detecting stuff\", true);\n } else {\n frontLeftWheel.setPower(0);\n backLeftWheel.setPower(0);\n frontRightWheel.setPower(0);\n backRightWheel.setPower(0);\n telemetry.addData(\"detecting stuff\", false);\n }\n }\n\n telemetry.addData(\"Angle to unit\", recognition.estimateAngleToObject(AngleUnit.DEGREES));\n telemetry.addData(\"Log\", log);\n\n }\n telemetry.update();\n }\n\n }\n }\n }\n if (tfod != null) {\n tfod.shutdown();\n }\n }", "@Override\n public void disabledInit() {\n\t\tprocessRobotModeChange(RobotMode.DISABLED);\n }", "@Override\n public void initialize() {\n //manualActivated = !manualActivated;\n }", "protected void finalAction(){\n Robot.stop();\n requestOpModeStop();\n }", "public void engineOff(){\n engine = false;\n }", "public void resetMode() {\n\t\televatorManager.resetMode();\n\t}", "private void actionSampleDetectionModeChanged ()\r\n\t{\r\n\t\tif (mainFormLink.getComponentPanelLeft().getComponentRadioModeAuto().isSelected())\r\n\t\t{\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleAdd().setEnabled(false);\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleAddControl().setEnabled(false);\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleDelete().setEnabled(false);\r\n\t\t}\r\n\r\n\t\tif (mainFormLink.getComponentPanelLeft().getComponentRadioModeManual().isSelected())\r\n\t\t{\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleAdd().setEnabled(true);\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleAddControl().setEnabled(true);\r\n\t\t\tmainFormLink.getComponentPanelLeft().getComponentSampleDelete().setEnabled(true);\r\n\t\t}\r\n\t}", "private void setModeUI(){\n\n if (this.inManualMode == true){ this.enableRadioButtons(); } // manual mode\n else if (this.inManualMode == false){ this.disableRadioButtons(); } // automatic mode\n }", "@Override\n\tpublic void onModeChange() {\n\t}", "public void normalMode() {\n this.brokenPumpNo = -1;\n if (howManyBrokenUnits()) {\n this.mode = State.EMERGENCY_STOP;\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.EMERGENCY_STOP));\n emergencyStopMode();\n return;\n }\n if (steamFailure()) { // if steam failure go to degraded mode\n this.mode = State.DEGRADED;\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.DEGRADED));\n this.outgoing.send(new Message(MessageKind.STEAM_FAILURE_DETECTION));\n this.waterLevel = this.levelMessage.getDoubleParameter();\n degradedMode();\n return;\n }\n\n // check for water-level detection failure\n if (waterLevelFailure() || this.levelMessage.getDoubleParameter() == 0) {\n // failure, goes to rescue mode\n this.outgoing.send(new Message(MessageKind.LEVEL_FAILURE_DETECTION));\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.RESCUE));\n this.mode = State.RESCUE;\n this.prevRescueMode = State.NORMAL;\n this.steamLevel = this.steamMessage.getDoubleParameter();\n rescueMode();\n return;\n }\n if (nearMaxMin() || overMax()) { // checks if water is near or over the max\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.EMERGENCY_STOP));\n this.mode = State.EMERGENCY_STOP;\n emergencyStopMode();\n return;\n }\n int no = pumpFailure();\n if (no != -1) { // check for any pump failure\n this.brokenPumpNo = no;\n this.mode = State.DEGRADED;\n this.prevDegradedMode = State.NORMAL;\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.DEGRADED));\n this.outgoing.send(new Message(MessageKind.PUMP_FAILURE_DETECTION_n, no));\n degradedMode();\n return;\n }\n no = pumpControllerFailure();\n if (no != -1) { // check for any controller failure\n this.mode = State.DEGRADED;\n this.prevDegradedMode = State.NORMAL;\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.DEGRADED));\n this.outgoing.send(new Message(MessageKind.PUMP_CONTROL_FAILURE_DETECTION_n, no));\n degradedMode();\n return;\n }\n\n // all error messages checked. Can run normal mode as per usual.\n this.outgoing.send(new Message(MessageKind.MODE_m, Mailbox.Mode.NORMAL));\n this.waterLevel = this.levelMessage.getDoubleParameter();\n this.steamLevel = this.steamMessage.getDoubleParameter();\n int noOfPumps = estimatePumps(this.steamMessage.getDoubleParameter(),\n this.levelMessage.getDoubleParameter());\n turnOnPumps(noOfPumps); // pump water in\n\n if (this.levelMessage.getDoubleParameter() < this.configuration.getMinimalNormalLevel()) {\n\n noOfPumps = estimatePumps(this.steamMessage.getDoubleParameter(),\n this.levelMessage.getDoubleParameter());\n turnOnPumps(noOfPumps);\n }\n if (this.levelMessage.getDoubleParameter() > this.configuration.getMaximalNormalLevel()) {\n // if it goes above max normal level\n noOfPumps = estimatePumps(this.steamMessage.getDoubleParameter(),\n this.levelMessage.getDoubleParameter());\n turnOnPumps(noOfPumps);\n }\n\n }", "@Override\n public final void switchUserMode() {\n }", "private void automaticModeChecks(){\n // turn on lights if underground\n if (this.isUnderground()){ this.selectedTrain.setLights(1);}\n // set heat\n if (this.selectedTrain.getTemp() <= 40.0){this.selectedTrain.setThermostat(60.0);}\n else if (this.selectedTrain.getTemp() >= 80){ this.selectedTrain.setThermostat(50.0);}\n }", "private void handle_mode_display() {\n\t\t\t\n\t\t}", "void enableFlipMode();", "public void toggleGodMode() {\n\t\tthis.isGodModeEnabled = !this.isGodModeEnabled;\n\t\tif (this.isGodModeEnabled) {\n\t\t\tSystem.out.println(\"GodMode Enabled.\");\n\t\t} else {\n\t\t\tSystem.out.println(\"GodMode Disabled.\");\n\t\t}\n\t}", "public RobotHardware (LinearOpMode opmode) {\n myOpMode = opmode;\n }", "public int invokeCutMode()\n{\n \n return(0);\n\n}", "@Override\n\tpublic void onEnable() {\n\t\tSystem.out.println(\"Modus: Forcedown\");\n\t\tArduinoInstruction.getInst().enable();\n\t\tArduinoInstruction.getInst().setControl((byte)0x40);\n\t}", "public void runOpMode(){\n JAWLDrive3796 drive = new JAWLDrive3796(hardwareMap.dcMotor.get(\"left_drive\"), hardwareMap.dcMotor.get(\"right_drive\"));\n //Set the drive motors to run without encoders\n drive.setEncoders(false);\n //Create Grabber object\n JAWLGrabber3796 grabber = new JAWLGrabber3796(hardwareMap.servo.get(\"left_arm\"), hardwareMap.servo.get(\"right_arm\"));\n //Create Lift object\n JAWLLift3796 lift = new JAWLLift3796(hardwareMap.dcMotor.get(\"lift_motor\"));\n //Create color arm object\n JAWLColorArm3796 colorArm = new JAWLColorArm3796(hardwareMap.servo.get(\"color_arm\"));\n //Creates color sensor name\n ColorSensor colorSensorTemp = hardwareMap.get(ColorSensor.class, \"color_distance\");\n //Creates distance sensor name\n DistanceSensor distanceSensorTemp = hardwareMap.get(DistanceSensor.class, \"color_distance\");\n //Creates the color-distance sensor object\n JAWLColorSensor3796 colorDistanceSensor = new JAWLColorSensor3796(colorSensorTemp, distanceSensorTemp);\n //Creates the variable that will hold the color of the jewel\n String colorOfBall;\n //Creates relic arm objects\n //TTTTRelicArm3796 relicArm = new TTTTRelicArm3796(hardwareMap.dcMotor.get(\"relic_up_down\"), hardwareMap.dcMotor.get(\"relic_out_in\"), hardwareMap.dcMotor.get(\"relic_grab\"));\n //We never ended up having a relic arm!\n //The lift helper will set the idle power of the motor to a small double, keeping the lift from idly falling down\n boolean liftHelper = false;\n int i = 0;\n\n waitForStart();\n\n colorArm.armUp();\n\n while (opModeIsActive()) {\n //Here is where we define how the controllers should work\n //In theory, no logic retaining to controlling the components should be in here\n\n /*\n * Drive\n */\n\n //The left drive wheel is controlled by the opposite value of the left stick's y value on the first gamepad\n //The right drive is the same way except with the right drive wheel\n drive.leftDrive(-gamepad1.left_stick_y);\n drive.rightDrive(-gamepad1.right_stick_y);\n\n /*\n * Lift\n */\n telemetry.addData(\"Gamepad2 Right Stick Y\", -gamepad2.right_stick_y);\n\n if (-gamepad2.right_stick_y > 0) {\n //First checks to see if the right stick's negative y value is greater then zero.\n lift.moveMotor(-gamepad2.right_stick_y);\n //If it is, it sets the power for the motor to 1, and adds telemetry\n telemetry.addData(\"Lift Power\", 1);\n } else if (-gamepad2.right_stick_y < 0) {\n //Checks if the negative value of the right right stick's y position is less than zero\n lift.moveMotor(-0.1);\n //Sets the power for the motor to -0.1, and adds telemetry\n telemetry.addData(\"Lift Power\", -0.1);\n } else {\n //We check to see if the liftHelper is enabled\n if(liftHelper) {\n lift.moveMotor(0.1466 );\n } else {\n lift.moveMotor(0);\n }\n }\n\n\n\n /*\n * Lift helper control\n */\n\n if(gamepad2.a) {\n if(i == 0) {\n liftHelper = !liftHelper;\n }\n i = 5;\n }\n\n if(i != 0) {\n i--;\n }\n\n telemetry.addData(\"Lift Helper Enabled\", liftHelper);\n\n\n\n /*\n * Grabbers\n */\n if (gamepad2.left_trigger > 0) {\n //Closes the left arm, then displays the position in telemetry\n grabber.leftArmClose();\n double a = grabber.leftPosition();\n //Adds telemetry to display positions of grabbers, mostly for testing, but can be useful later on\n telemetry.addData(\"Left\", a);\n }\n\n if (gamepad2.left_bumper) {\n //Opens the left arm, then displays the position in telemetry\n grabber.leftArmOpen();\n double b = grabber.leftPosition();\n //We made the variables different as to avoid any and all possible errors\n telemetry.addData(\"Left\", b);\n }\n\n if (gamepad2.right_trigger > 0) {\n //Opens the right arm, then displays the position in telemetry\n grabber.rightArmClose();\n double c = grabber.rightPosition();\n telemetry.addData(\"Right\", c);\n }\n\n if (gamepad2.right_bumper) {\n //Closes the right arm, then displays the position in telemetry\n grabber.rightArmOpen();\n double d = grabber.rightPosition();\n telemetry.addData(\"Right\", d);\n }\n\n if (gamepad2.dpad_left){\n //Closes the left arm to a shorter distance\n grabber.leftArmShort();\n }\n\n if(gamepad2.dpad_right){\n //Closes the right arm to a shorter distance\n grabber.rightArmShort();\n\n }\n\n //Update all of our telemetries at once so we can see all of it at the same time\n telemetry.update();\n }\n }", "@Override\n public void disabledInit() {\n //Diagnostics.writeString(\"State\", \"DISABLED\");\n }", "@Override\n public void runOpMode() {\n int selectedstate = 0;\n //set variable selecting to true for the selecting while loop\n boolean selecting = true;\n\n askState(states.colorRed, states.colorBlue);\n if (ask(\"Default Starting Position\", \"Alternate Starting Position\")) {\n if (ask(\"First Beacon\", \"Second Beacon which has now been broken so don't run it\")) {\n askState(states.arcTowardsBeacon);\n askState(states.scanForLine);\n askState(states.driveTowardsBeacon);\n askState(states.pushBeaconButton, states.sleep0);\n askState(states.backAwayFromBeacon);\n askState(states.shootballTwoBalls, states.shootballOnce, states.noscope);\n askState(states.correctStrafe);\n askState(states.slideToTheRight);\n askState(states.scanForLine);\n askState(states.driveTowardsBeacon);\n askState(states.pushBeaconButton, states.sleep0);\n if (ask(\"Corner Vortex\", \"Center Vortex\")) {\n askState(states.pivotbeacon);\n askState(states.rotate60);\n askState(states.backup84);\n } else {\n askState(states.pivotbeacon, states.pivotbeaconless);\n askState(states.backuptovortex, states.backuptovortexIncreased, states.backuptovortexReduced);\n }\n } else {\n// askState(states.driveFoward36);\n askState(states.arcTowardsBeacon24);\n askState(states.scanForLine);\n askState(states.driveTowardsBeacon);\n askState(states.pushBeaconButton, states.sleep0);\n askState(states.backAwayFromBeacon5);\n askState(states.slideToTheLeft);\n askState(states.scanForLineInverted);\n askState(states.driveTowardsBeacon);\n askState(states.pushBeaconButton, states.sleep0);\n askState(states.backAwayFromBeacon);\n askState(states.shootballTwoBalls, states.shootballOnce, states.noscope);\n askState(states.rotate110);\n askState(states.backup30);\n }\n } else {\n askState(states.sleep0, states.sleep2000, states.sleep4000, states.sleep10000);\n askState(states.backup42);\n askState(states.shootballTwoBalls, states.shootballOnce, states.noscope);\n askState(states.sleep0, states.sleep2000, states.sleep4000, states.sleep10000);\n if (ask(\"Corner Vortex\", \"Center Vortex\")) {\n askState(states.arc2);\n askState(states.driveFoward48);\n } else {\n askState(states.rotate40);\n askState(states.backup24);\n }\n }\n\n askState(states.sleep0);\n\n if (ask(\"Ready to init?\", \"Ready to init? asked again so I don't need to make a new method\")) {\n\n }\n\n // send whole LinearOpMode object and context to robotconfig init method\n robot.init(this);\n //add telementry to report that init completed\n robotconfig.addlog(dl, \"autonomous\", \"Done with robot.init --- waiting for start in \" + this.getClass().getSimpleName());\n\n //convert list of states to be run to array for theoretical performance reasons\n runlist = list.toArray(new state[list.size()]);\n //run each state multiple times until the state increases the currentState variable by 1\n currentState = 0;\n //default current color to purple, first state will either redefine it as red or blue\n states.color = 0;\n //add telementry data to display if debug mode is active, debug mode is used to test to make sure objects are oriented correctly without having actual hardware attached\n telemetry.addData(\"Say\", \"Hello Driver - debug mode is \" + robotconfig.debugMode);\n displayStates();\n //display telementry data\n telemetry.update();\n waitForStart();\n //add log to log file\n robotconfig.addlog(dl, \"autonomous\", \"Started\");\n //loop while match is running\n while (opModeIsActive()) {\n\n robotconfig.addlog(dl, \"Mainline\", \"Beginning state machine pass \" + String.format(Locale.ENGLISH, \"%d\", currentState));\n\n //check if the currentState is more than the last index of the runlist\n if (currentState + 1 < runlist.length) {\n telemetry.addData(\"state\", runlist[currentState].name);\n telemetry.update();\n //run the state from the runlist of the currentState index\n runlist[currentState].run();\n //add log of name of state that ran for debugging\n robotconfig.addlog(dl, \"Mainline\", \"Ending state machine pass of \" + runlist[currentState].name);\n } else {\n //if completed last state, stop\n robot.move(0, 0, 0);\n //add log to tell us that the program finished all selected states before stopping\n robotconfig.addlog(dl, \"StateMachine\", \"stop requested\");\n requestOpModeStop();\n }\n\n }\n\n robot.move(0, 0, 0);\n robot.pushButton(0);\n //add log to tell us that the program stopped smoothly\n robotconfig.addlog(dl, \"autonomous\", \"Done with opmode, exited based on OpmodeIsActive false\");\n\n }", "@Override\n public void runOpMode() throws InterruptedException\n {\n leftDrive = hardwareMap.dcMotor.get(\"left_drive\");\n rightDrive = hardwareMap.dcMotor.get(\"right_drive\");\n\n leftDrive.setDirection(DcMotor.Direction.REVERSE);\n\n telemetry.addData(\"Mode\", \"waiting\");\n telemetry.update();\n\n // wait for start button.\n\n waitForStart();\n\n telemetry.addData(\"Mode\", \"running\");\n telemetry.update();\n\n // set both motors to 25% power.\n\n leftDrive.setPower(0.25);\n rightDrive.setPower(0.25);\n\n sleep(2000); // wait for 2 seconds.\n\n // set motor power to zero to stop motors.\n\n leftDrive.setPower(0.0);\n rightDrive.setPower(0.0);\n }", "@Override\n public void runOpMode() {\n\n //PUTS THE NAMES OF THE MOTORS INTO THE CODE\n\n //DRIVE Motors\n aDrive = hardwareMap.get(DcMotor.class, \"aDrive\");\n bDrive = hardwareMap.get(DcMotor.class, \"bDrive\");\n cDrive = hardwareMap.get(DcMotor.class, \"cDrive\");\n dDrive = hardwareMap.get(DcMotor.class, \"dDrive\");\n cDrive.setDirection(DcMotor.Direction.REVERSE);\n dDrive.setDirection(DcMotor.Direction.REVERSE);\n\n //FUNCTIONS Motors\n Arm = hardwareMap.get(DcMotor.class, \"Arm\");\n ArmExtender = hardwareMap.get(DcMotor.class, \"ArmExtender\");\n Spindle = hardwareMap.get(DcMotor.class, \"Spindle\");\n Lift = hardwareMap.get(DcMotor.class, \"Lift\");\n\n //SERVOS\n Cover = hardwareMap.get(Servo.class, \"Cover\");\n\n //Vuforia\n telemetry.addData(\"Status\", \"DogeCV 2018.0 - Gold Align Example\");\n\n detector = new GoldAlignDetector();\n detector.init(hardwareMap.appContext, CameraViewDisplay.getInstance());\n detector.useDefaults();\n\n // Phone Stuff\n detector.alignSize = 100; // How wide (in pixels) is the range in which the gold object will be aligned. (Represented by green bars in the preview)\n detector.alignPosOffset = 0; // How far from center frame to offset this alignment zone.\n detector.downscale = 0.4; // How much to downscale the input frames\n detector.areaScoringMethod = DogeCV.AreaScoringMethod.MAX_AREA; // Can also be PERFECT_AREA\n //detector.perfectAreaScorer.perfectArea = 10000; // if using PERFECT_AREA scoring\n detector.maxAreaScorer.weight = 0.005;\n detector.ratioScorer.weight = 5;\n detector.ratioScorer.perfectRatio = 1.0;\n detector.enable();\n telemetry.addData(\"Status\", \"Initialized\");\n telemetry.update();\n\n waitForStart();\n\n telemetry.addData(\"IsAligned\" , detector.getAligned()); // Is the bot aligned with the gold mineral\n\n goldPos = detector.getXPosition(); // Gets gold block posistion\n\n sleep(1000); // Waits to make sure it is correct\n\n // Move Depending on gold position\n if(goldPos < 160){\n driftleft();\n sleep(1500);\n }else if (goldPos > 500) {\n driftright();\n sleep(1500);\n }else{\n forward();\n }\n\n forward(); //Drives into crater\n sleep(4000);\n\n detector.disable();\n\n }", "public void switchCore() {\n\t\tnoCore = !(noCore);\n\t}", "default void onDisable() {}", "@Override\n public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n return false;\n }", "public void operatorControl() {\n myRobot.setSafetyEnabled(true);\n while (isOperatorControl() && isEnabled()) {\n \tmyRobot.tankDrive(controller, 2, controller, 5);\n Timer.delay(0.005);\t\t// wait for a motor update time\n }\n }", "protected void execute()\n\t{\n\t\tif(enable)\n\t\tRobot.winch.respoolWinch();\n\t}", "@Test\n public void mustNotEnableMoreThanOnce() throws RemoteException {\n mHbmController.enable(mOnEnabled);\n\n // Should set the appropriate refresh rate for UDFPS and notify the caller.\n verify(mDisplayCallback).onHbmEnabled(eq(DISPLAY_ID));\n verify(mOnEnabled).run();\n\n // Second request to enable the UDFPS mode, while it's still enabled.\n mHbmController.enable(mOnEnabled);\n\n // Should ignore the second request.\n verifyNoMoreInteractions(mDisplayCallback);\n verifyNoMoreInteractions(mOnEnabled);\n }", "public void change() {\r\n this.mode = !this.mode;\r\n }", "public abstract void wgb_onDisable();", "@Override\r\n\t\t\t\tpublic boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n\t\t\t\t\treturn false;\r\n\t\t\t\t}", "@Override\r\n public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n return false;\r\n }", "public void onEnabled() {\r\n }", "@Override public void init_loop() {\n if (gyro.isCalibrated()) {\n telemetry.addData(\"Gyro\", \"Calibrated\");\n }\n\n /** Place any code that should repeatedly run after INIT is pressed but before the op mode starts here. **/\n }", "@Override\n\tpublic void disabledInit() {\n\t\tRobot.driveSubsystem.setCoastMode();\n\t}", "@Test\n public void mustNotDisableMoreThanOnce() throws RemoteException {\n mHbmController.enable(mOnEnabled);\n\n // Should set the appropriate refresh rate for UDFPS and notify the caller.\n verify(mDisplayCallback).onHbmEnabled(eq(DISPLAY_ID));\n verify(mOnEnabled).run();\n\n // First request to disable the UDFPS mode.\n mHbmController.disable(mOnDisabled);\n\n // Should unset the refresh rate and notify the caller.\n verify(mOnDisabled).run();\n verify(mDisplayCallback).onHbmDisabled(eq(DISPLAY_ID));\n\n // Second request to disable the UDFPS mode, when it's already disabled.\n mHbmController.disable(mOnDisabled);\n\n // Should ignore the second request.\n verifyNoMoreInteractions(mOnDisabled);\n verifyNoMoreInteractions(mDisplayCallback);\n }", "public abstract void Enabled();", "protected void onDisabled() {\n // Do nothing.\n }", "@Override\n public void run() {\n mode = NONE;\n }", "public void onEnable() {\n }", "private void fixEnabled(){\n setEnabled(graph.getUndoManager().canRedo());\n }", "public void disable() {\r\n m_enabled = false;\r\n useOutput(0, 0);\r\n }", "public void disabledInit()\n\t{\n\t\t\n\t}", "@Override\r\n public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\r\n return false; // Return false if nothing is done\r\n }", "@Override\n public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n return false;\n }", "@Override\n\t\t\tpublic boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n\t\t\t\treturn false;\n\t\t\t}", "default void onAutoModeChanged(int autoMode) {}", "@Override\n public void runOpMode() throws InterruptedException {\n initialize();\n\n waitForStart();\n\n /* drivetrain.Strafe(1F, 5, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(1F, 5, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(1F, 10, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(1F, 10, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(1F, 20, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(1F, 20, Direction.LEFT); */\n\n sleep(6000);\n\n drivetrain.Strafe(.5F, 5, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 5, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.5F, 10, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 10, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.5F, 20, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 20, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.5F, 30, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 30, Direction.LEFT);\n\n Balanced_Strafe(.5F, 5, Direction.RIGHT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 5, Direction.LEFT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.RIGHT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.LEFT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.RIGHT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.LEFT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.RIGHT, 1.1f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.LEFT, 1.1f, this);\n\n Balanced_Strafe(.5F, 5, Direction.RIGHT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 5, Direction.LEFT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.RIGHT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.LEFT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.RIGHT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.LEFT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.RIGHT, 1.3f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.LEFT, 1.3f, this);\n\n Balanced_Strafe(.5F, 5, Direction.RIGHT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 5, Direction.LEFT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.RIGHT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.LEFT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.RIGHT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.LEFT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.RIGHT, 1.5f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.LEFT, 1.5f, this);\n\n Balanced_Strafe(.5F, 5, Direction.RIGHT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 5, Direction.LEFT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.RIGHT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 10, Direction.LEFT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.RIGHT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 20, Direction.LEFT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.RIGHT, 2f, this);\n sleep(2000);\n Balanced_Strafe(.5F, 30, Direction.LEFT, 2f, this);\n\n\n /*drivetrain.Strafe(.75F, 5, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.75F, 5, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.75F, 10, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.75F, 10, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.75F, 20, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.75F, 20, Direction.LEFT);\n sleep(6000);\n\n drivetrain.Strafe(.5F, 5, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 5, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.5F, 10, Direction.RIGHT);\n sleep(2000);\n\n\n drivetrain.Strafe(.5F, 10, Direction.LEFT);\n sleep(2000);\n drivetrain.Strafe(.5F, 20, Direction.RIGHT);\n sleep(2000);\n drivetrain.Strafe(.5F, 20, Direction.LEFT);\n sleep(2000); */\n\n drivetrain.StopAll();\n\n\n\n }", "boolean hasMode();", "public void resetAllOperations() {\n\t\t/*\n\t\t * Check to see if we are in any countdown modes\n\t\t */\n\t\tif(inCountdown1Mode) {\n\t\t\twarmUpWindow1.dismiss();\n\t\t}\t\t\n\t\tif(inBaselineMode) {\n\t\t\tbaselineWindow.dismiss();\n\t\t}\n\t\t\n\t\t/**\n\t\t * Turn off any red leds\n\t\t */\n\t\tledOn1.setVisibility(View.INVISIBLE);\n\t\tledOn2.setVisibility(View.INVISIBLE);\n\t\tledOn3.setVisibility(View.INVISIBLE);\n\t\tledOn4.setVisibility(View.INVISIBLE);\n\t\tledOn5.setVisibility(View.INVISIBLE);\n\t\tledOn6.setVisibility(View.INVISIBLE);\n\t\tledOn7.setVisibility(View.INVISIBLE);\n\t\tledOn8.setVisibility(View.INVISIBLE);\n\t\tledOn9.setVisibility(View.INVISIBLE);\n\t\t\n\t\t/*\n\t\t * Reset any program flow variables\n\t\t */\n\t\tinCountdown1Mode = false;\n\t\tinBaselineMode = false;\n\t\ton = false;\n\t\tmodeChange = false;\n\t\twarmedUp = false;\n\t\t\n\t\t/*\n\t\t * Reset counts\n\t\t */\n\t\tcountdown1 = WARMUP_COUNT;\n\t\tcountdown2 = BASELINE_COUNT;\n\t\ttvUpdate(tvSensorValue, \"--\");\n\t\t\n\t\tcountdown1Handler.removeCallbacksAndMessages(null);\n\t\tcountdown2Handler.removeCallbacksAndMessages(null);\n\t\tmodeHandler.removeCallbacksAndMessages(null);\n\t\ttickHandler.removeCallbacksAndMessages(null);\n\t\tsetLEDsHandler.removeCallbacksAndMessages(null);\n\t\t\n\t\t// Stop taking measurements\n\t\tstreamer.disable();\n\t\t// Disable the sensor\n\t\tdroneApp.myDrone.quickDisable(qsSensor);\n\t}", "@Override\n\t public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n\t return false; // Return false if nothing is done\n\t }", "void verifyModesEnable(String mode);", "public void setManualMode(boolean b){\n\n this.inManualMode = b;\n }", "@Override\n public boolean onPrepareActionMode(ActionMode mode, Menu menu) {\n return false;\n }" ]
[ "0.7218687", "0.70883465", "0.68440586", "0.6828813", "0.67650455", "0.6723159", "0.665032", "0.6556356", "0.6555784", "0.652499", "0.6470446", "0.6459811", "0.6415281", "0.64098233", "0.64084053", "0.6385399", "0.6381864", "0.63631314", "0.63502395", "0.63021505", "0.62992936", "0.62907326", "0.6282187", "0.62734", "0.6267155", "0.6255194", "0.6242937", "0.618128", "0.6180164", "0.61663663", "0.6162988", "0.6149602", "0.61416775", "0.6093409", "0.6092973", "0.60804987", "0.6058777", "0.6049905", "0.6010299", "0.6007918", "0.5996081", "0.5995888", "0.59850717", "0.59784985", "0.59721863", "0.59577996", "0.59556067", "0.5949541", "0.5929035", "0.59153897", "0.5888869", "0.5874511", "0.58633953", "0.58593863", "0.5858665", "0.5836269", "0.5833195", "0.58279335", "0.58275646", "0.58234036", "0.58213377", "0.5818428", "0.5817791", "0.58165693", "0.5806094", "0.5804489", "0.57924926", "0.5787808", "0.57807606", "0.5779889", "0.57716244", "0.5761117", "0.57502306", "0.5750225", "0.57448155", "0.57421005", "0.57300866", "0.5727212", "0.57270384", "0.5726326", "0.5714216", "0.57076687", "0.5706644", "0.5701835", "0.5699741", "0.56991637", "0.5697937", "0.569402", "0.5680859", "0.56764907", "0.56754726", "0.56737864", "0.56649965", "0.56498224", "0.5648165", "0.56442916", "0.5640774", "0.5640092", "0.5639431", "0.5638196", "0.56352514" ]
0.0
-1
The activity must call the GL surface view's onResume() on activity onResume().
@Override protected void onResume() { super.onResume(); mGLSurfaceView.onResume(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n protected void onResume() {\n super.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n public void onResume() {\n \tsuper.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tmGLView.onResume();\n\t}", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tourSurfaceView.onResume();\n\t}", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\n\t\tourSurfaceView.resume();\n\t}", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tsurfaceView.resume();\n\t}", "@Override\r\n protected void onResume() {\r\n Log.d(LOGTAG, \"onResume\");\r\n super.onResume();\r\n\r\n // This is needed for some Droid devices to force portrait\r\n if (mIsDroidDevice) {\r\n setRequestedOrientation(ActivityInfo.SCREEN_ORIENTATION_LANDSCAPE);\r\n setRequestedOrientation(ActivityInfo.SCREEN_ORIENTATION_PORTRAIT);\r\n }\r\n\r\n try {\r\n vuforiaAppSession.resumeAR();\r\n } catch (ArException e) {\r\n Log.e(LOGTAG, e.getString());\r\n }\r\n\r\n // Resume the GL view:\r\n if (mGlView != null) {\r\n mGlView.setVisibility(View.VISIBLE);\r\n mGlView.onResume();\r\n }\r\n }", "protected void onResume()\n {\n super.onResume();\n\n // Resumen específico de QCAR\n QCAR.onResume();\n\n // Si la cámara ya se ha iniciado alguna vez la volvemos a iniciar\n if (mEstadoActualAPP == EstadoAPP.CAMERA_STOPPED)\n {\n actualizarEstadoAplicacion(EstadoAPP.CAMERA_RUNNING);\n }\n\n // Resumen específico del OpenGL ES View\n if (mGlView != null)\n {\n mGlView.setVisibility(View.VISIBLE);\n mGlView.onResume();\n }\n }", "@Override\n protected void onResume() {\n super.onResume();\n\n //Execute the game view's resume method\n gameEngine.resume();\n }", "public void resume() {\n // This must be safe to call multiple times\n Util.validateMainThread();\n Log.d(TAG, \"resume()\");\n\n // initCamera() does nothing if called twice, but does log a warning\n initCamera();\n\n if (currentSurfaceSize != null) {\n // The activity was paused but not stopped, so the surface still exists. Therefore\n // surfaceCreated() won't be called, so init the camera here.\n startPreviewIfReady();\n } else if(surfaceView != null) {\n // Install the callback and wait for surfaceCreated() to init the camera.\n surfaceView.getHolder().addCallback(surfaceCallback);\n } else if(textureView != null && Build.VERSION.SDK_INT >= 14) {\n textureView.setSurfaceTextureListener(surfaceTextureListener());\n }\n\n // To trigger surfaceSized again\n requestLayout();\n rotationListener.listen(getContext(), rotationCallback);\n }", "@Override\n protected void onResume() {\n super.onResume();\n\n // Tell the gameView resume method to execute\n gameView.resume();\n }", "@Override\n protected void onResume() {\n super.onResume();\n\n // Tell the gameView resume method to execute\n gameView.resume();\n }", "@Override\n protected void onResume() {\n super.onResume();\n //admobView.resume();\n gameView.onResume();\n }", "@Override\n protected void onPause()\n {\n super.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n protected void onPause()\n {\n super.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n protected void onResume() {\n super.onResume();\n Log.d(TAG, \"onResume\");\n\n game();\n }", "@Override\n protected void onPause() {\n super.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n protected void onResume() {\n super.onResume();\n init();\n decideScreen();\n }", "@Override\n protected void onResume() {\n super.onResume();\n cameraLiveView.onResume();\n }", "public void onResume() {\n super.onResume();\n drawUI();\n }", "public void onResume();", "@Override\n public void onPause() {\n \tsuper.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n protected void onResume() {\n Log.i(\"G53MDP\", \"Main onResume\");\n super.onResume();\n }", "void onResume();", "public final void \n onResume() {\n \t\n \tthis.isPaused = false;\n \tthis.isResumed = true;\n \tthis.mLastTextureId = 0;\n \tsuper.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n setUpScreen();\n }", "@Override\r\n protected void onResume() {\n super.onResume();\r\n mapView.onResume();\r\n }", "public void onResume() {\n super.onResume();\n }", "public void onResume() {\n super.onResume();\n }", "public void onResume() {\n super.onResume();\n C8006j.m18079r();\n }", "@Override\n protected void onResume() {\n super.onResume();\n mapView.onResume();\n }", "@Override\n protected void onResume() {\n super.onResume();\n cameraView.start();\n }", "@Override\r\n\tpublic void onResume() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void onResume() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void onResume() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void onResume() {\n\t\t\r\n\t}", "@Override\n\tprotected void onResume() {\n\t\t\n\t\tinit();\n\t\tsuper.onResume();\n\n\t}", "public void onResume() {\n }", "protected abstract void onResume();", "@Override\n public void onResume() {\n }", "@Override\r\n\tpublic void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tpublic void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tpublic void onResume() {\n\t\tsuper.onResume();\r\n\t}", "protected void onResume ()\n\t{\n\t\tsuper.onResume ();\n\t}", "@Override\n protected void onResume() {\n super.onResume();\n\n\n if (locationScene != null) {\n locationScene.resume();\n }\n\n if (arSceneView.getSession() == null) {\n // If the session wasn't created yet, don't resume rendering.\n // This can happen if ARCore needs to be updated or permissions are not granted yet.\n try {\n Session session = DemoUtils.createArSession(this, installRequested);\n if (session == null) {\n installRequested = ARLocationPermissionHelper.hasPermission(this);\n return;\n } else {\n arSceneView.setupSession(session);\n }\n } catch (UnavailableException e) {\n DemoUtils.handleSessionException(this, e);\n }\n }\n\n try {\n arSceneView.resume();\n } catch (CameraNotAvailableException ex) {\n DemoUtils.displayError(this, \"Unable to get camera\", ex);\n finish();\n return;\n }\n\n if (arSceneView.getSession() != null) {\n showLoadingMessage();\n }\n\n mapView.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n mapView.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n mapView.onResume();\n }", "@Override\r\n\tpublic void onResume() {\n\t\tsuper.onResume();\r\n\t\t\r\n\t}", "@Override\r\n protected void onResume() {\n super.onResume();\r\n Log.i(TAG, \"onResume\");\r\n\r\n }", "@Override\r\n\tprotected void onResume() {\n\t\t\r\n\t}", "@Override\n protected void onResume() {\n super.onResume();\n Log.d(TAG, \"onResume() called\");\n }", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tmGLSurfaceView.onPause();\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t}", "@Override\n protected void onResume() {\n super.onResume();\n\n if (locationScene != null) {\n locationScene.resume();\n }\n\n if (arSceneView.getSession() == null) {\n // If the session wasn't created yet, don't resume rendering.\n // This can happen if ARCore needs to be updated or permissions are not granted yet.\n try {\n Session session = DemoUtils.createArSession(this, installRequested);\n if (session == null) {\n installRequested = ARLocationPermissionHelper.hasPermission(this);\n return;\n } else {\n arSceneView.setupSession(session);\n }\n } catch (UnavailableException e) {\n DemoUtils.handleSessionException(this, e);\n }\n }\n\n try {\n arSceneView.resume();\n } catch (CameraNotAvailableException ex) {\n DemoUtils.displayError(this, \"Unable to get camera\", ex);\n finish();\n return;\n }\n\n if (arSceneView.getSession() != null) {\n showLoadingMessage();\n }\n }", "@Override\r\n protected void onResume() {\r\n Log.i(TAG, \"onResume()\");\r\n \r\n super.onResume();\r\n }", "@Override\r\n protected void onResume() {\n mDjiGLSurfaceView.resume();\r\n \r\n mTimer = new Timer();\r\n Task task = new Task();\r\n mTimer.schedule(task, 0, 500); \r\n \r\n DJIDrone.getDjiMC().startUpdateTimer(1000);\r\n super.onResume();\r\n }", "@Override\r\n\tprotected void onResume() {\n\t\tXSDK.getInstance().onResume();\r\n\t\tsuper.onResume();\r\n\t}", "public void onResume() {\n if (mCamera == null) {\n obtainCameraOrFinish();\n }\n }", "@Override\n\tprotected void onResume() \n\t{\n\t\tsuper.onResume();\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t\t\r\n\t}", "@Override\r\n\tprotected void onResume() {\n\t\tsuper.onResume();\r\n\t\t\r\n\t}", "@Override\n public void onViewResume() {\n }", "@Override\n\tpublic void resume() {\n\t\tGdx.app.log(\"GameScreen\", \"resume called\"); \n\t}", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tUMengStatistticUtil.onResumeForFragmentActivity(this);\n\n\t}", "protected void onBSResume() {\n checkBSActivityRunning();\n mDrawer.addBSParentView(mInitialWaveform, mInitialDithering);// show\n // user UI\n // on back\n // screen\n isResumed = true;\n mCalled = true;\n }", "@Override\n protected void onCreate(Bundle savedInstanceState) {\n requestWindowFeature(Window.FEATURE_NO_TITLE);\n super.onCreate(savedInstanceState);\n getWindow().setFlags(WindowManager.LayoutParams.FLAG_FULLSCREEN, WindowManager.LayoutParams.FLAG_FULLSCREEN);\n GLSurfaceView view = new GLSurfaceView(this);\n view.setEGLConfigChooser(8, 8, 8, 8, 16, 0); //Transparent background\n view.getHolder().setFormat(PixelFormat.TRANSLUCENT); //Transparent background\n view.setRenderer(new OpenGLRenderer(this));\n setContentView(view);\n //Transition to Landing screen\n new Handler().postDelayed(new Runnable() {\n\n @Override\n public void run() {\n // This app main activity\n Intent i = new Intent(SplashActivity.this, SearchActivity.class);\n startActivity(i);\n finish();\n }\n }, SPLASH_TIME_OUT);\n }", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tshowPoints();\n\t}", "@Override\n protected void onResume() {\n mapView.onResume();\n super.onResume();\n }", "@Override\n\tprotected void onResume()\n\t{\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\n\t}", "@Override\n\tpublic void onResume() {\n\n\t}", "@Override\n public void onResume() {\n super.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n }", "@Override\n public void onResume() {\n super.onResume();\n }", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t}", "@Override\n public void onResume() {\n\n super.onResume();\n }", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\tLog.i(TAG, module + \" Entra por onResume\");\n\t}", "@Override\n\tprotected void onResume() {\n\t\tsuper.onResume();\n\t\t \n\t}", "@Override\n\tpublic void onResume() {\n\t\tsuper.onResume();\n\t\tif (DEBUG>=2) Log.d(TAG, \"onResumed'd\");\n\t\tIS_PAUSING = NO;\n\t\twl.acquire();\n\t\tpreview.onResume();\n\t}", "@Override\n protected void onPause() {\n super.onPause();\n releaseCamera();\n mGLView.queueEvent(new Runnable() {\n @Override public void run() {\n // Tell the renderer that it's about to be paused so it can clean up.\n mRenderer.notifyPausing();\n }\n });\n mGLView.onPause();\n// Log.d(TAG, \"onPause complete\");\n }" ]
[ "0.9159589", "0.91277796", "0.87837905", "0.848264", "0.8351304", "0.82544804", "0.80400294", "0.7781469", "0.76859254", "0.7595853", "0.7470616", "0.7470616", "0.7360346", "0.7341314", "0.7341314", "0.7327331", "0.7309444", "0.7302582", "0.7257028", "0.7234893", "0.7220193", "0.7188503", "0.71822894", "0.71733505", "0.717092", "0.7158892", "0.71364045", "0.71259046", "0.71259046", "0.7117202", "0.7107397", "0.7088689", "0.7087609", "0.7087609", "0.7087609", "0.7087609", "0.70816386", "0.7074311", "0.7068777", "0.7068264", "0.70674795", "0.70674795", "0.70674795", "0.7066691", "0.706401", "0.70498437", "0.70498437", "0.70455885", "0.7039108", "0.70347035", "0.70302784", "0.70247424", "0.7023704", "0.7023704", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7021317", "0.7017476", "0.7014807", "0.7006968", "0.7004519", "0.6994714", "0.6994412", "0.6994243", "0.6994243", "0.6990416", "0.69897896", "0.6985243", "0.6984928", "0.69787145", "0.6968424", "0.69640833", "0.6959099", "0.69576716", "0.69576716", "0.6956987", "0.6956987", "0.6956987", "0.6956987", "0.6956987", "0.694885", "0.694885", "0.694885", "0.694885", "0.694885", "0.694885", "0.694885", "0.69397557", "0.6939107", "0.69320756", "0.693207", "0.69312567" ]
0.9171822
1
The activity must call the GL surface view's onPause() on activity onPause().
@Override protected void onPause() { super.onPause(); mGLSurfaceView.onPause(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n protected void onPause() {\n super.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n public void onPause() {\n \tsuper.onPause();\n mGLSurfaceView.onPause();\n }", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tmGLSurfaceView.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tmGLView.onPause();\n\t}", "@Override\n protected void onPause() {\n super.onPause();\n releaseCamera();\n mGLView.queueEvent(new Runnable() {\n @Override public void run() {\n // Tell the renderer that it's about to be paused so it can clean up.\n mRenderer.notifyPausing();\n }\n });\n mGLView.onPause();\n// Log.d(TAG, \"onPause complete\");\n }", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tourSurfaceView.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tourSurfaceView.pause();\n\n\t}", "protected void onPause()\n {\n super.onPause();\n\n if (mGlView != null)\n {\n mGlView.setVisibility(View.INVISIBLE);\n mGlView.onPause();\n }\n\n if (mEstadoActualAPP == EstadoAPP.CAMERA_RUNNING)\n {\n actualizarEstadoAplicacion(EstadoAPP.CAMERA_STOPPED);\n }\n\n if (mFlash)\n {\n mFlash = false;\n setFlash(mFlash);\n }\n\n QCAR.onPause();\n }", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tsurfaceView.pause();\n\t}", "public void onPause() {\n releaseCamera();\n }", "@Override\n protected void onPause() {\n ReleaseCamera();\n super.onPause();\n }", "@Override\r\n protected void onPause() {\n mDjiGLSurfaceView.pause();\r\n \r\n if(mTimer!=null) { \r\n mTimer.cancel();\r\n mTimer.purge();\r\n mTimer = null;\r\n }\r\n \r\n DJIDrone.getDjiMC().stopUpdateTimer();\r\n super.onPause();\r\n }", "@Override\n protected void onPause() {\n super.onPause();\n releaseCamera();\n }", "@Override\n protected void onResume()\n {\n super.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n protected void onResume()\n {\n super.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n public void onResume() {\n \tsuper.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n protected void onPause() {\n mapView.onPause();\n deactivate();\n super.onPause();\n }", "@Override\n protected void onResume() {\n super.onResume();\n mGLSurfaceView.onResume();\n }", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\treleaseCamera();\n\t}", "@Override\r\n protected void onPause() {\n super.onPause();\r\n mapview.onPause();\r\n }", "@Override\r\n protected void onPause() {\n super.onPause();\r\n mapView.onPause();\r\n }", "@Override\n protected void onPause() {\n super.onPause();\n\n //Execute the game view's pause method\n gameEngine.pause();\n }", "@Override\r\n protected void onPause() {\r\n Log.d(LOGTAG, \"onPause\");\r\n super.onPause();\r\n\r\n if (mGlView != null) {\r\n mGlView.setVisibility(View.INVISIBLE);\r\n mGlView.onPause();\r\n }\r\n\r\n // Turn off the flash\r\n if (mFlashOptionView != null && mFlash) {\r\n // OnCheckedChangeListener is called upon changing the checked state\r\n if (Build.VERSION.SDK_INT >= Build.VERSION_CODES.JELLY_BEAN_MR1) {\r\n ((Switch) mFlashOptionView).setChecked(false);\r\n } else {\r\n ((CheckBox) mFlashOptionView).setChecked(false);\r\n }\r\n }\r\n\r\n try {\r\n vuforiaAppSession.pauseAR();\r\n } catch (ArException e) {\r\n Log.e(LOGTAG, e.getString());\r\n }\r\n }", "@Override\n protected void onPause() {\n Log.i(\"G53MDP\", \"Main onPause\");\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n //admobView.pause();\n gameView.onPause();\n }", "@Override\n\tprotected void onPause()\n\t{\n\t\tsuper.onPause();\n\t}", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tpublic void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tpublic void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\r\n\tpublic void onPause() {\n\t\tsuper.onPause();\r\n\t}", "@Override\n protected void onPause() {\n super.onPause();\n mMapView.onPause();\n }", "@Override\r\n\tprotected void onPause() {\n\t\tXSDK.getInstance().onPause();\r\n\t\tsuper.onPause();\r\n\t}", "@Override\n protected void onPause() {\n super.onPause();\n destroyARX(); // Stop ARX and release resources.\n }", "public void onPause() {\n super.onPause();\n }", "public void onPause() {\n super.onPause();\n }", "public void onPause() {\n super.onPause();\n }", "public void onPause() {\n super.onPause();\n }", "public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n\n if (locationScene != null) {\n locationScene.pause();\n }\n\n arSceneView.pause();\n mapView.onPause();\n }", "@Override\n\tpublic void onPause() \n\t{\n\t\tsuper.onPause();\n\t\tgyroscope.onPause();\n\t}", "protected void onPause(Bundle savedInstanceState) {\r\n\t\t\r\n\t}", "public void onPause() {\n super.onPause();\r\n }", "@Override\n public void onPause() {\n mCameraView.stop();\n super.onPause();\n }", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tpublic void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\tSalinlahiFour.getBgm().pause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t}", "@Override\n public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n }", "public void onPause();", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n protected void onPause() {\n super.onPause();\n }", "@Override\n\tprotected void onPause()\n\t{\n\t\tsuper.onPause();\n\n\t}", "protected void onPause() {\n super.onPause();\n }", "@Override\n public void onPause() {\n super.onPause();\n Log.d(TAG, \"onPause saving layers\");\n }", "@Override\n \tprotected void onPause() {\n \t\tsuper.onPause();\n \t}", "@Override\n \tprotected void onPause() {\n \t\tsuper.onPause();\n \t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\t\n\t}", "@Override\n\tprotected void onPause() {\n\t\tsuper.onPause();\n\t\t\n\t}", "@Override\n protected void onPause() {\n super.onPause();\n if(mvTencentMapView != null) {\n mvTencentMapView.onPause();\n }\n }", "@Override\r\n\tprotected void onPause() {\n\t\tsuper.onPause();\r\n\t\tfinish();\r\n\t}", "@Override\n\t\tprotected void onPause() {\n\t\t\tsuper.onPause();\n\t\t}" ]
[ "0.8832655", "0.8734953", "0.8688291", "0.8431665", "0.8350776", "0.80450004", "0.7792342", "0.7651672", "0.7580013", "0.7497345", "0.7484416", "0.73815125", "0.7376477", "0.7366757", "0.7366757", "0.7338082", "0.73281544", "0.7318343", "0.72775435", "0.72610027", "0.7223264", "0.7173662", "0.7143665", "0.7143564", "0.71152246", "0.7091824", "0.70854664", "0.70854664", "0.70854664", "0.70854664", "0.70854664", "0.70852935", "0.70852935", "0.70852935", "0.7066955", "0.7053205", "0.70519423", "0.704084", "0.704084", "0.704084", "0.704084", "0.704084", "0.7038723", "0.7038631", "0.70384103", "0.7038261", "0.703579", "0.7034613", "0.7034613", "0.7034613", "0.7034613", "0.7034613", "0.7034613", "0.7034613", "0.7032989", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7029223", "0.7026909", "0.7026909", "0.7026909", "0.7026909", "0.7026909", "0.7026909", "0.7026043", "0.7017554", "0.7017554", "0.7017554", "0.7017554", "0.7017554", "0.7017554", "0.7017554", "0.6999496", "0.6991474", "0.6986882", "0.6985236", "0.6985236", "0.69793266", "0.69793266", "0.69588554", "0.69560796", "0.6955098" ]
0.88510925
1
HashSet visited = new HashSet();
public static void postOrderTraverse2(TreeNode head){ if(head == null) return; Stack<TreeNode> stack = new Stack<>(); stack.push(head); TreeNode node; while (!stack.isEmpty()){ while (( node = stack.peek()) != null){ if(node.lChild != null && node.lChild.visited == true){ stack.push(null); break; } stack.push(node.lChild); } stack.pop(); //空指针出栈 if(!stack.isEmpty()){ node = stack.peek(); if(node.rChild == null || node.rChild.visited == true){ System.out.print(node.val + " "); node.visited = true; stack.pop(); }else { stack.push(node.rChild); } } } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setVisited()\n {\n visited = true;\n }", "public void resetVisited() {\n\t\tthis.visited = new HashSet<Point>();\n\t}", "public void clearVisited()\n {\n visited = false;\n }", "public void setVisited(boolean value){this.visited = value;}", "public boolean getVisited(){return this.visited;}", "public boolean isVisited(){\n return visited;\n }", "private boolean visited(int hashCode){\n \t\t//.add returns true if hashCode was added (meaning hashCode haven't been added before)\n \t\tif(visited.add(hashCode))\n \t\t\treturn false;\n \t\telse\n \t\t\treturn true;\n \t}", "public boolean getVisited()\n {\n return visited;\n }", "public void visit() {\n visited = true;\n }", "public void setVisited(Boolean b){\n visited = b;\n }", "public boolean WasVisited() { return _visited; }", "public void setVisited(Boolean visited) {\n this.visited = visited;\n }", "public void setVisited(boolean visited)\n\t{\n\t\tthis.visited = visited;\n\t}", "public boolean getVisited() {\n return visited;\n }", "public void setVisited(boolean visited) {\n this.visited = visited;\n }", "private void clearVisited(){\r\n\t\tfor(int i=0; i<graphSize; i++){\r\n\t\t\tmyGraph[i].visited = false;\r\n\t\t\tAdjVertex vert = myGraph[i].adjVertexHead;\r\n\t\t\twhile(vert != null){\r\n\t\t\t\tvert.visited = false;\r\n\t\t\t\tvert= vert.next;\r\n\t\t\t}\r\n\t\t}\r\n\t}", "public void setVisited(boolean flag) {\n\t\tvisited = flag;\n\t}", "public static Map<Integer, Boolean> InitializeVisited() {\n\t\tMap<Integer, Boolean> visited = new HashMap<Integer, Boolean>();\r\n\t\tfor (Entry<Integer, Vertex> currentVertex : vertexes.entrySet())\r\n\t\t\tvisited.put(currentVertex.getKey(), false);\r\n\t\treturn visited;\r\n\t}", "public void setVisited(boolean visited) {\r\n\t\t\tthis.visited = visited;\r\n\t\t}", "public void setVisited(boolean visited) {\n isVisited = visited;\n }", "public void visit() {\n\t\tvisited = true;\n\t}", "public boolean isVisited() {\n return visited;\n }", "public boolean isVisited()\n\t{\n\t\treturn visited;\n\t}", "void changeVisited(){\n\t \t\tthis.isVisited = true;}", "public boolean isVisited() {\n return visited;\n }", "void mo30185a(HashSet<zzawj> hashSet);", "private void dfs(Node s, HashSet<Integer> visited) {\n\t\tif(visited.contains(s.id)) {\n\t\t\treturn;\n\t\t}\n\t\tSystem.out.println(s.id);\n\t\tvisited.add(s.id);\n\t\tfor(Node n :s.adj) {\n\t\t\tdfs(n,visited);\n\t\t}\n\t}", "public boolean isVisited() {\n\t\treturn visited;\n\t}", "public void setVisited(boolean b) {\n\t\t_visited = b;\n\t}", "public InternalWorkingOfHashSet() {\r\n map = new HashMap<>();\r\n }", "@Override public Set<L> vertices() {\r\n return new HashSet<L>(vertices);//防御式拷贝\r\n }", "boolean isVisited();", "boolean isVisited();", "public boolean hasBeenVisited() {\n\t\treturn visited; // Replace with your code\n\t}", "public Set<URLPair> getVisited() { return this.pool.getVisitedKeys(); }", "private void reachable(Set s) {\n for (Iterator i = this.succ.iterator(); i.hasNext(); ) {\n IdentityHashCodeWrapper ap = (IdentityHashCodeWrapper)i.next();\n if (!s.contains(ap)) {\n s.add(ap);\n ((AccessPath)ap.getObject()).reachable(s);\n }\n }\n }", "private void setAllUnvisited(){\n\t\tfor(int i = 0; i < this.getDimension(); i++)\n\t\t\tthis.getGraph().setUnvisited(i);\n\t\tthis.visited = 0;\n\t}", "public void clear() {\n\t\tvisited = false;\n\t}", "@Override\r\n\tpublic boolean isVisited() {\n\t\treturn false;\r\n\t}", "private void addAsUseful(HashSet visited, HashSet path, Node n) {\n if (path.contains(n)) {\n return;\n }\n path.add(n);\n if (visited.contains(n)) {\n if (VERIFY_ASSERTIONS) Assert._assert(nodes.containsKey(n), n.toString());\n return;\n }\n if (n instanceof UnknownTypeNode) {\n path.remove(n);\n return;\n }\n visited.add(n); this.nodes.put(n, n);\n if (TRACE_INTER) out.println(\"Useful: \"+n);\n for (Iterator i = n.getNonEscapingEdgeTargets().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node) i.next());\n }\n if (n.accessPathEdges != null) {\n for (Iterator i=n.accessPathEdges.entrySet().iterator(); i.hasNext(); ) {\n Map.Entry e = (Map.Entry) i.next();\n Object o = e.getValue();\n if (o instanceof Node) {\n if (!addIfUseful(visited, path, (Node)o)) {\n i.remove();\n }\n } else {\n boolean any = false;\n for (Iterator j=((Set)o).iterator(); j.hasNext(); ) {\n Node j_n = (Node)j.next();\n if (!addIfUseful(visited, path, j_n)) {\n j.remove();\n } else {\n any = true;\n }\n }\n if (!any) i.remove();\n }\n }\n }\n for (Iterator i = n.getPredecessorTargets().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node) i.next());\n }\n if (n instanceof FieldNode) {\n FieldNode fn = (FieldNode) n;\n for (Iterator i = fn.getAccessPathPredecessors().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node)i.next());\n }\n }\n // Call \"addIfUseful()\" on all successor checkcast nodes.\n if (castPredecessors.contains(n)) {\n for (Iterator i = castMap.entrySet().iterator(); i.hasNext(); ) {\n Map.Entry e = (Map.Entry)i.next();\n Node goestocast = (Node)((Pair)e.getKey()).left;\n CheckCastNode castsucc = (CheckCastNode)e.getValue();\n if (n == goestocast)\n addIfUseful(visited, path, castsucc);\n }\n }\n\n // call \"addAsUseful()\" on all predecessors.\n if (n instanceof CheckCastNode) {\n Quad thiscast = ((QuadProgramLocation)((CheckCastNode)n).getLocation()).getQuad();\n for (Iterator i = castPredecessors.iterator(); i.hasNext(); ) {\n Node goestocast = (Node)i.next();\n CheckCastNode castsucc = (CheckCastNode)castMap.get(new Pair(goestocast, thiscast));\n if (castsucc != null)\n addAsUseful(visited, path, goestocast);\n }\n }\n path.remove(n);\n }", "public void markAllNodesAsUnvisited() {\r\n visitedToken++;\r\n }", "static void dfs(Node current, Set<Node> visited) {\n System.out.print(\"Node \" + current.val + \", \");\n\n // adds the current node to the set of already visited nodes\n visited.add(current);\n\n // loops over the neighbours of the current node\n for (Node neighbour: current.neighbours) {\n\n // if the neighbour has not been already visited\n if (! visited.contains(neighbour)) {\n\n // recursively processes the neighbour\n dfs(neighbour, visited);\n }\n }\n }", "public Set<Edge<V>> edgeSet();", "private Set<E> toSet(Node<E> n) {\n Set<E> result = new HashSet<>();\n toSet(result, n);\n return result;\n }", "private void visitDFS(Dot node, Set< Dot > visited ) {\n\n board.getNeighbors( node ).forEach( nbr -> {\n if ( !visited.contains( nbr ) ) {\n visited.add( nbr );\n visitDFS( nbr, visited );\n }\n } );\n }", "private void bfs(Node node, HashSet<Integer> visited) {\n\t\tLinkedList<Node> queue = new LinkedList<Node>();\n\t\tvisited.add(node.id);\n\t\tqueue.add(node);\n\t\twhile(!queue.isEmpty()) {\n\t\t\tNode s = queue.remove();\n\t\t\tSystem.out.println(s.id);\n\t\t\tfor(Node n : s.adj) {\n\t\t\t\tif(!visited.contains(n.id)) {\n\t\t\t\t\tqueue.add(n);\n\t\t\t\t\tvisited.add(n.id);\n\t\t\t\t}\n\t\t\t\t\n\t\t\t}\n\t\t}\n\t}", "public boolean isVisited() {\n\t\treturn _visited;\n\t}", "public void resetVisited() {\r\n\t\tvisited = false;\r\n\t\tfor (ASTNode child : getChildren()) {\r\n\t\t\tif (!visited)\r\n\t\t\t\tcontinue;\r\n\t\t\tchild.resetVisited();\r\n\t\t}\r\n\t}", "public static void main(String[] args) {\n\t\tArrayList al=new ArrayList();\r\n\t\tal.add(1);\r\n\t\tal.add(2);\r\n\t\tal.add(3);\r\n\t\tal.add(4);\r\n\t\tal.add(1);\r\n\t\tal.add(2);\r\n\t\tSystem.out.println(\"Elements in ArrayList: \"+al);\r\n\t\t\r\n\t\tLinkedHashSet<Integer> lhs=new LinkedHashSet<Integer>(al);\r\n\t\tSystem.out.println(\"linkedhashset: \"+lhs);\r\n\t}", "public MyHashSet() {\n nodes = new Node[Max_Size];\n }", "public void setNodesToUnvisited(){\n for(GraphNode node: graphNode){\n if(node.visited){\n node.visited = false;\n }\n }\n }", "private static void usingLinkedHashSet()\n\t{\n Integer[] numbers = new Integer[] {1,2,3,4,5,1,3,5};\n \n //This array has duplicate elements\n System.out.println( Arrays.toString(numbers) );\n \n //Create set from array elements\n LinkedHashSet<Integer> linkedHashSet = new LinkedHashSet<>( Arrays.asList(numbers) );\n \n //Get back the array without duplicates\n Integer[] numbersWithoutDuplicates = linkedHashSet.toArray(new Integer[] {});\n \n //Verify the array content\n System.out.println( Arrays.toString(numbersWithoutDuplicates) );\n\t}", "public void hashSet() {\n\n Set<Integer> num = new java.util.HashSet<>();\n\n num.add(3);\n num.add(11);\n num.add(6);\n\n System.out.println(num);\n\n for (int i = 1; i <= 10; i++) {\n\n if (num.contains(i)) {\n\n System.out.println(\"\\n\\t\" + i + \"\\t is found in set\");\n\n }\n\n }\n\n }", "void dfs(){\n // start from the index 0\n for (int vertex=0; vertex<v; vertex++){\n // check visited or not\n if (visited[vertex]==false){\n Explore(vertex);\n }\n }\n }", "public void dfs() {\n\t\tfor (Vertice v : vertices) {\n\t\t\tv.setVisited(false);\n\t\t}\n\t\tfor (Vertice v : vertices) {\n\t\t\tif (!v.getVisited()) {\n\t\t\t\tVisitar(v, -1);\n\t\t\t}\n\t\t}\n\t}", "public MyMultiset() {\n\t\tthis.set = new HashSet<Node>();\n\t}", "public Object clone()\n/* */ {\n/* 251 */ return new IntHashSet(this);\n/* */ }", "private void setAtomsToUnVisited(IMolecule molecule) {\n\t\tfor (int i = 0; i < molecule.getAtomCount(); i++) {\n\t\t\tmolecule.getAtom(i).setFlag(CDKConstants.VISITED, false);\n\t\t}\n\t}", "public void dfs() {\n int currentVertexIndex = 0;\r\n dfsStack.push(0);\r\n vertexList[0].wasVisited = true;\r\n System.out.println(vertexList[dfsStack.peek()]);\r\n while (dfsStack.top != -1) {\r\n\r\n\r\n currentVertexIndex = this.getAdjUnvisitedVert(dfsStack.peek());\r\n if (currentVertexIndex != -1) {\r\n dfsStack.push(currentVertexIndex);\r\n vertexList[currentVertexIndex].wasVisited = true;\r\n System.out.println(vertexList[dfsStack.peek()]);\r\n\r\n\r\n } else {\r\n currentVertexIndex = dfsStack.pop();\r\n\r\n }\r\n }\r\n// reset wasVisted\r\n for (Vertex x : vertexList) {\r\n x.wasVisited = false;\r\n }\r\n }", "@PortedFrom(file = \"Taxonomy.h\", name = \"clearCheckedLabel\")\n protected void clearVisited() {\n visitedLabel++;\n }", "public boolean isVisited() {\n return isVisited;\n }", "public void setVisited(int v) {\n visited.set(v, true);\n nodeEnum.add(v);\n }", "@Override\n\tpublic Set<NFAState> eClosure(NFAState s) {\n\t\tSet<NFAState> visited = new TreeSet<NFAState>();\n\t\t//invoke recursive helper\n\t\tvisited = eClosureHelper(s, visited);\n\t\t\n\t\treturn visited;\n\t}", "public static void main(String[] args) {\r\n\t\tHashSet h1=new HashSet();\r\n\t\t\r\n\t\t\r\n\t\t\r\n\t\t\r\n\t\th1.add(3);\r\n\t\th1.add(7); //Homogeous \r\n\t\th1.add(9);//hetrogeous\r\n\t\th1.add(10);\r\n\t\t\r\n\t\tTreeSet t1=new TreeSet(h1);\r\n\t\tt1.add(100);\r\n\t\tSystem.out.println(t1);\r\n\t}", "public Iterator iterator()\n {\n return new HashSetIterator();\n }", "public MyHashSet() {\n s = new ArrayList<>();\n }", "public boolean isVisited() {\r\n\t\t\treturn this.visited;\r\n\t\t}", "void getSinkSet(){\n\t\tsink = new HashSet<>(inlinks.keySet());\n\t\tfor(String node : outlinks.keySet()){\n\t\t\tif(!(sink.add(node))){\n\t\t\t\tsink.remove(node);\n\t\t\t}\n\t\t}\n\t\t\n\t\tSystem.out.println(\"Sink Size : \"+sink.size());\n\t }", "private Collection<Edge> getEdges()\r\n\t{\r\n\t return eSet;\r\n\t}", "public static void main(String[] args) {\n HashSet<Person> set = new HashSet<>();\n Person p1 = new Person(\"小妹妹\", 18);\n Person p2 = new Person(\"小妹妹\", 18);\n Person p3 = new Person(\"小妹妹\", 19);\n System.out.println(p1.hashCode());\n System.out.println(p2.hashCode());\n System.out.println(p1 == p2);\n System.out.println(p1.equals(p2));\n set.add(p1);\n set.add(p2);\n set.add(p3);\n System.out.println(set);\n }", "private Set<NFAState> eClosureHelper(NFAState s, Set<NFAState> visited ) {\n\t\t//check if eClosure is possible on the given state\n\t\tif (!s.hasNextE()) {\n\t\t\tif (visited.size() == 0) {\n\t\t\t\treturn null;\n\t\t\t}\n\t\t\treturn visited;\n\t\t}\n\t\t\n\t\tSet<NFAState> newStates = s.getTo('e');\n\t\t\n\t\tfor (NFAState state: newStates) {\n\t\t\tfor(NFAState visitedState : visited) {\n\t\t\t\tif(state.getName().equals(visitedState.getName())) {\n\t\t\t\t\t//if the current state is already in visited, return to avoid an infinite loop\n\t\t\t\t\treturn visited;\n\t\t\t\t}\n\t\t\t}\n\t\t\tvisited.add(state);\n\t\t\tvisited.addAll(eClosureHelper(state, visited));\n\t\t\t\n\t\t}\n\t\t\n\t\treturn visited;\n\n\t}", "public void clearNodeVisitedMarking() {\n\tfor (Node n : nodes)\n\t n.clearVisitedMark();\n }", "public static Set<List<Vertex>> breadthFirstSearch(Graph graph) {\n\n Set<List<Vertex>> arrayListHashSet=new HashSet<>();\n\n for(Vertex v : graph.getVertices()){\n ArrayList<Vertex> visitedArrayList=new ArrayList<>();\n Queue<Vertex> vertexQueue=new ArrayDeque<>();\n visitedArrayList.add(v);\n vertexQueue.offer(v);\n while (!vertexQueue.isEmpty()){\n for(Vertex v1:graph.getNeighbors(vertexQueue.poll())){\n if(!visitedArrayList.contains(v1)){\n visitedArrayList.add(v1);\n vertexQueue.offer(v1);\n }\n }\n }\n arrayListHashSet.add(visitedArrayList);\n }\n return arrayListHashSet; // this should be changed\n }", "protected HashSet getNotTraversable(){\n tester.removeTraversedComponents();\n return tester.traversableComponents;\n }", "public Set<String> getNeverVisited() {\n Set<String> neverVisited = new TreeSet<String>();\n this.getNeverVisited(this, neverVisited, null);\n return neverVisited;\n }", "public HashSet<N> getNodes()\r\n/* 99: */ {\r\n/* 100:182 */ assert (checkRep());\r\n/* 101: */ \r\n/* 102:184 */ return new HashSet(this.map.keySet());\r\n/* 103: */ }", "@Override\n public int hashCode() {\n return Objects.hashCode(nodes(), edgeToIncidentNodes);\n }", "public Set<E> getEdges();", "public MyHashSet() {\n \n }", "void DFSUtil(int v, boolean visited[]) {\n\t\t\tvisited[v] = true;\n\t\t\tSystem.out.println(v +\" \");\n\t\t\t\n\t\t\t//Recur all the vertices adjacents to this vertex\n\t\t\tIterator<Integer> i = adj[v].listIterator();\n\t\t\twhile(i.hasNext()) {\n\t\t\t\tint node = i.next();\n\t\t\t\tif(!visited[node]) {\n\t\t\t\t\tDFSUtil(node, visited);\n\t\t\t\t}\n\t\t\t}\n\t\t}", "public HashSet<Town> getVertices() {\r\n\t\treturn (HashSet<Town>) vertices;\r\n\t}", "void DFS() {\n \t\n \t// Mark all the vertices as not visited(set as false by default in java) \n \tboolean visited[] = new boolean[V];\n \t\n \t// Call the recursive helper function to print DFS traversal \n // starting from all vertices one by one \n \tfor (int i=0; i<V; i++) { \n \t\t if (visited[i] == false)\n \t\t\t DFSUtil(i, visited);\n \t}\n }", "public static void main(String[] args) {\n HashSet<String> hashSet = new HashSet<>();\n hashSet.add(\"Orange\");\n hashSet.add(\"Red\");\n hashSet.add(\"Pink\");\n hashSet.add(\"Red\");\n hashSet.add(\"White\");\n System.out.println(hashSet);\n TreeSet<String> treeSet = new TreeSet<>(hashSet);\n for (String color : treeSet) {\n System.out.println(color);\n }\n\n }", "protected IntHashSet getMemberHashSet() {\n\t\treturn memberHashSet;\n\t}", "public Set<V> getNeighbours(V vertex);", "public static Set<List<Vertex>> depthFirstSearch(Graph graph) {\n Set<List<Vertex>> arrayListHashSet=new HashSet<>();\n\n for(int i=0;i<graph.getVertices().size();i++){\n ArrayList<Vertex> visitedArrayList=new ArrayList<>();\n for(int j=0;j<graph.getVertices().size();j++){\n if(visitedArrayList.size()==0){\n if(!visitedArrayList.contains(graph.getVertices().get(i))){\n depthFirstSearch(graph.getVertices().get(i),visitedArrayList,graph);\n }\n }\n else{\n if(!visitedArrayList.contains(graph.getVertices().get(j))){\n depthFirstSearch(graph.getVertices().get(j),visitedArrayList,graph);\n }\n }\n }\n arrayListHashSet.add(visitedArrayList);\n }\n return arrayListHashSet; // this should be changed\n }", "public abstract HashSet<Location> getPossibleMovements(GameBoard board);", "public DesignHashSet() {\n map=new HashMap<>();\n }", "Dijk(){\n grp = new HashMap<>();\n seen = new HashSet<>();\n dlist = new HashMap<>();\n id = new HashMap<>();\n lowlink = new HashMap<>();\n orid = 0;\n }", "public static void main(String[] args) {\n HashSet<Person> set = new HashSet<>(10);\n for (int i = 0; i < 10; i++) {\n set.add(new Person(\"person\" + i, i));\n }\n for (int i = 0; i < 10; i++) {\n set.add(new Person(\"person\", 15));\n }\n Person p1 = new Person(\"person\", 15);\n Person p2 = new Person(\"person\", 15);\n System.out.println(p1 + \" hascode: \" + p1.hashCode());\n System.out.println(p2 + \" hascode: \" + p2.hashCode());\n System.out.println(\"person1 equals person2 \" + p1.equals(p2));\n for (Person person : set) {\n System.out.println(person);\n }\n }", "public void mst() {\n int currentVertexIndex = 0;\r\n dfsStack.push(0);\r\n vertexList[0].wasVisited = true;\r\n// System.out.println(vertexList[dfsStack.peek()]);\r\n while (dfsStack.top != -1) {\r\n\r\n\r\n currentVertexIndex = this.getAdjUnvisitedVert(dfsStack.peek());\r\n if (currentVertexIndex != -1) {\r\n System.out.print(vertexList[dfsStack.peek()]);\r\n dfsStack.push(currentVertexIndex);\r\n vertexList[currentVertexIndex].wasVisited = true;\r\n System.out.print(vertexList[dfsStack.peek()]);\r\n System.out.print(\", \");\r\n\r\n\r\n } else {\r\n currentVertexIndex = dfsStack.pop();\r\n\r\n }\r\n }\r\n for (Vertex x : vertexList) {\r\n x.wasVisited = false;\r\n }\r\n }", "public static void main(String[] args) {\n int [] A = {5,1,5,2,5,3,5,4};\n HashSet<Integer> aa = new HashSet<>();\n for (int i = 0; i <A.length ; i++) {\n if (aa.contains(A[i])) {\n System.out.println(A[i]);\n break;\n }else\n aa.add(A[i]);\n\n }\n\n }", "private boolean addIfUseful(HashSet visited, HashSet path, Node n) {\n if (path.contains(n)) return true;\n path.add(n);\n if (visited.contains(n)) return nodes.containsKey(n);\n visited.add(n);\n boolean useful = false;\n if (nodes.containsKey(n)) {\n if (TRACE_INTER) out.println(\"Useful: \"+n);\n useful = true;\n }\n if (n instanceof UnknownTypeNode) {\n path.remove(n);\n return true;\n }\n if (n.addedEdges != null) {\n if (TRACE_INTER) out.println(\"Useful because of added edge: \"+n);\n useful = true;\n for (Iterator i = n.getNonEscapingEdgeTargets().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node) i.next());\n }\n }\n if (n.accessPathEdges != null) {\n for (Iterator i = n.accessPathEdges.entrySet().iterator(); i.hasNext(); ) {\n java.util.Map.Entry e = (java.util.Map.Entry)i.next();\n //jq_Field f = (jq_Field)e.getKey();\n Object o = e.getValue();\n if (o instanceof Node) {\n if (addIfUseful(visited, path, (Node)o)) {\n if (TRACE_INTER && !useful) out.println(\"Useful because outside edge: \"+n+\"->\"+o);\n useful = true;\n } else {\n if (n != o) i.remove();\n }\n } else {\n for (Iterator j=((Set)o).iterator(); j.hasNext(); ) {\n Node n2 = (Node)j.next();\n if (addIfUseful(visited, path, n2)) {\n if (TRACE_INTER && !useful) out.println(\"Useful because outside edge: \"+n+\"->\"+n2);\n useful = true;\n } else {\n if (n != n2) j.remove();\n }\n }\n if (!useful) i.remove();\n }\n }\n }\n if (castPredecessors.contains(n)) {\n for (Iterator i = castMap.entrySet().iterator(); i.hasNext(); ) {\n Map.Entry e = (Map.Entry)i.next();\n Node goestocast = (Node)((Pair)e.getKey()).left;\n CheckCastNode castsucc = (CheckCastNode)e.getValue();\n // Call \"addIfUseful()\" on all successor checkcast nodes, and set the \"useful\" flag if the call returns true.\n if (n == goestocast && addIfUseful(visited, path, castsucc))\n useful = true;\n }\n }\n if (n instanceof ReturnedNode) {\n if (TRACE_INTER && !useful) out.println(\"Useful because ReturnedNode: \"+n);\n useful = true;\n }\n if (n.predecessors != null) {\n useful = true;\n if (TRACE_INTER && !useful) out.println(\"Useful because target of added edge: \"+n);\n for (Iterator i = n.getPredecessorTargets().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node) i.next());\n }\n }\n if (useful) {\n this.nodes.put(n, n);\n if (n instanceof FieldNode) {\n FieldNode fn = (FieldNode)n;\n for (Iterator i = fn.getAccessPathPredecessors().iterator(); i.hasNext(); ) {\n addAsUseful(visited, path, (Node)i.next());\n }\n }\n if (n instanceof CheckCastNode) {\n // If the \"useful\" flag is true and the node is a checkcast node,\n // call \"addAsUseful()\" on all predecessors.\n Quad thiscast = ((QuadProgramLocation)((CheckCastNode)n).getLocation()).getQuad();\n for (Iterator i = castPredecessors.iterator(); i.hasNext(); ) {\n Node goestocast = (Node)i.next();\n CheckCastNode castsucc = (CheckCastNode)castMap.get(new Pair(goestocast, thiscast));\n if (castsucc != null)\n addAsUseful(visited, path, goestocast);\n }\n }\n }\n if (TRACE_INTER && !useful) out.println(\"Not useful: \"+n);\n path.remove(n);\n return useful;\n }", "public static void main(String[] args) {\n Set<Integer> S1 = new TreeSet<>();\r\n // add objects\r\n S1.add(65); S1.add(36); S1.add(24); S1.add(36);\r\n \r\n // show the content and assert they are sorted and no duplications\r\n System.out.println(\"set = \" + S1); \r\n //remove elements\r\n S1.remove(36); S1.remove(24);\r\n System.out.println(S1); //assert set = 65\r\n S1.add(15); S1.add(24); S1.add(80); // add 15, 24, 80\r\n System.out.println(\"set = \" +S1); //assert set = 15, 24, 65, 80\r\n \r\n System.out.println(\"Does S1 contain 10?\"\r\n + S1.contains(10)); // assert false\r\n System.out.println(\"S1 has \" + S1.size() +\" objects\"); // assert 4\r\n\r\n // create another Set object implemented using HashSet\r\n Set<Integer> S2 = new HashSet<>();\r\n // add all objects in S1 to S2\r\n S2.addAll(S1);\r\n System.out.println(\"hashset = \" +S2); //assert they may not be ordered\r\n\r\n // create another Set object implemented using LinkedHashSet\r\n Set<Integer> S3 = new LinkedHashSet<>();\r\n S3.add(150); // add 150\r\n S3.addAll(S1);// add all objects in S1 to S2\r\n System.out.println(\"LinkedHashSet = \" +S3);//assert s3=[150,15,24,65,80]\r\n \r\n S3.removeAll(S3); // remove all items\r\n System.out.println(\"LinkedHashSet = \" +S3);//assert s3=[]\r\n }", "public HashSet<Position> getNeighborPos() { return neighborPos; }", "Set<String> dfsTraversal(Graph graph, String root) {\n Set<String> seen = new LinkedHashSet<String>();\n Stack<String> stack = new Stack<String>();\n stack.push(root);\n\n while (!stack.isEmpty()) {\n String node = stack.pop();\n if (!seen.contains(node)) {\n seen.add(node);\n for (Node n : graph.getAdjacentNodes(node)) {\n stack.push(n.data);\n }\n\n }\n }\n\n return seen;\n }", "public boolean visited(int i) {\r\n return visited[i] == visitedToken;\r\n }", "public MutableNodeSet(Graph graph) {\n\t\tsuper(graph);\n\t\tthis.members = new TreeSet<Integer>();\n\t\tinitializeInOutWeights();\n\t}", "private static void dfsAgain(int[][] arr, int sv, boolean[] visited, Stack<Integer> stack, ArrayList<Integer> list) {\n\t\t\n\t\twhile(!stack.isEmpty()) {\n\t\t\tint top=stack.pop();\n\t\t\tif(!visited[top]) {\n\t\t\t\t\n\t\t\tvisited[top]= true;\n\t\t\tfor(int i=0;i<arr.length;i++) {\n\t\t\t\tif(arr[top][i]==1 && !visited[i]) {\n\t\t\t\t\tvisited[i]=true;\n\t\t\t\t\tlist.add(i);\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void DFS() {\n\t\tfor(Node node: nodeList) {\r\n\t\t\tif(!node.isVisited())\r\n\t\t\t\tdfsVisit(node);\r\n\t\t}\r\n\t}", "private static int findConnectedComponents(Map<Integer, Set<Integer>> graph, boolean[] visited) {\n int count = 0;\n for (int u : graph.keySet()) {\n if (!visited[u]) {\n dfs(u, graph, visited);\n count++;\n }\n }\n return count;\n }" ]
[ "0.7541651", "0.7378335", "0.72635496", "0.7101113", "0.7030284", "0.68498427", "0.67915833", "0.67700315", "0.672014", "0.6688198", "0.66633946", "0.6657503", "0.65999556", "0.65739816", "0.6530075", "0.6516627", "0.64494604", "0.6431533", "0.642827", "0.64278823", "0.6420777", "0.6354856", "0.6348406", "0.6295341", "0.6255963", "0.621381", "0.62122893", "0.6205609", "0.61800724", "0.61679095", "0.6121728", "0.60847354", "0.60847354", "0.60764295", "0.6053974", "0.60486513", "0.60417676", "0.603945", "0.6037839", "0.6027103", "0.60244256", "0.6002765", "0.59833014", "0.59685504", "0.5945202", "0.59430945", "0.5937228", "0.5903747", "0.5898951", "0.5879138", "0.5871691", "0.58510023", "0.584484", "0.58334476", "0.5783201", "0.57628244", "0.575542", "0.5754218", "0.5748636", "0.57474035", "0.5735986", "0.5725651", "0.5724594", "0.5718084", "0.5712512", "0.5709168", "0.57006526", "0.56994385", "0.568553", "0.5678842", "0.5671537", "0.56711465", "0.5670308", "0.566181", "0.5636612", "0.5635936", "0.5621359", "0.5616917", "0.56159276", "0.56139284", "0.5606363", "0.55959636", "0.55931634", "0.5588694", "0.5588669", "0.55745703", "0.5561287", "0.55559754", "0.5552123", "0.55492234", "0.55463666", "0.5536186", "0.5530861", "0.5525813", "0.5524191", "0.55235755", "0.55180055", "0.54977405", "0.54839206", "0.5483843", "0.54736984" ]
0.0
-1
metoda za provjeru tacnosti unosa(tip podataka)
public static double provjera() { double broj = 0; boolean provjera = true; do { //ucitavanje unosa i provjera da li je int try { broj = unos.nextDouble(); //ako je sve ok, vrati broj provjera = false; } //hvata greska i trazi ponovni unos catch (InputMismatchException ex) { System.out.println("Pogresan unos. Pokusajte ponovo: "); unos.nextLine(); } } while (provjera); return broj; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void tallennaTiedostoon() {\n viitearkisto.tallenna();\n }", "private String tulostuksenApu(){\r\n String apu = \"Rivitiedosto: \";\r\n for(int i = 0; i<rivitiedot.length; i++){\r\n apu = apu + i+\": \";\r\n for(int k = 1; k <= rivitiedot[i].getKoko(); k++){\r\n apu = apu + \" \"+rivitiedot[i].get(k);\r\n }\r\n apu = apu + \" \";\r\n }\r\n\r\n return apu;\r\n }", "public Tequisquiapan()\n {\n nivel = new Counter(\"Barrio Tequisquiapan: \");\n \n nivel.setValue(5);\n hombre.escenario=5;\n\n casa5.creaCasa(4);\n addObject(casa5, 2, 3);\n \n arbol2.creaArbol(2);\n addObject(arbol2, 20, 3);\n arbol3.creaArbol(3);\n addObject(arbol3, 20, 16); \n \n addObject(letrero5, 15, 8);\n\n addObject(hombre, 11, 1);\n \n arbol4.creaArbol(4);\n addObject(arbol4, 20, 20);\n arbol5.creaArbol(5);\n addObject(arbol5, 3, 17);\n \n fuente2.creaAfuera(6);\n addObject(fuente2, 11, 19);\n \n lampara1.creaAfuera(2);\n addObject(lampara1, 8, 14);\n lampara2.creaAfuera(1);\n addObject(lampara2, 8, 7);\n \n addObject(nivel, 5, 0);\n addObject(atras, 20, 2); \n }", "private void ucitajTestPodatke() {\n\t\tList<Integer> l1 = new ArrayList<Integer>();\n\n\t\tRestoran r1 = new Restoran(\"Palazzo Bianco\", \"Bulevar Cara Dušana 21\", KategorijeRestorana.PICERIJA, l1, l1);\n\t\tRestoran r2 = new Restoran(\"Ananda\", \"Petra Drapšina 51\", KategorijeRestorana.DOMACA, l1, l1);\n\t\tRestoran r3 = new Restoran(\"Dizni\", \"Bulevar cara Lazara 92\", KategorijeRestorana.POSLASTICARNICA, l1, l1);\n\n\t\tdodajRestoran(r1);\n\t\tdodajRestoran(r2);\n\t\tdodajRestoran(r3);\n\t}", "protected String elaboraTemplateAvviso() {\n String testo = VUOTA;\n String dataCorrente = date.get();\n String personeTxt = \"\";\n personeTxt = text.format(numVoci);\n\n if (usaHeadTemplateAvviso) {\n testo += tagHeadTemplateAvviso;\n testo += \"|bio=\";\n testo += personeTxt;\n testo += \"|data=\";\n testo += dataCorrente.trim();\n testo += \"|progetto=\";\n testo += tagHeadTemplateProgetto;\n testo = LibWiki.setGraffe(testo);\n }// end of if cycle\n\n return testo;\n }", "public void atakuj() {\n\n System.out.println(\"to metoda atakuj z klasy Potwor \");\n\n }", "public Tura() {\n\t\tLicznikTur = 0;\n\t}", "public TrazAqui(){\n this.utilizadores = new TreeMap<>();\n this.encomendas = new TreeMap<>();\n this.utilizador = null;\n }", "public int getTilaa() {\r\n return maara - matkustajia;\r\n }", "@Test\n public void getTarjetaPrepagoTest()\n {\n TarjetaPrepagoEntity entity = data.get(0);\n TarjetaPrepagoEntity resultEntity = tarjetaPrepagoLogic.getTarjetaPrepago(entity.getId());\n Assert.assertNotNull(resultEntity);\n Assert.assertEquals(entity.getId(), resultEntity.getId());\n Assert.assertEquals(entity.getNumTarjetaPrepago(), resultEntity.getNumTarjetaPrepago());\n Assert.assertEquals(entity.getSaldo(), resultEntity.getSaldo(), 0.001);\n Assert.assertEquals(entity.getPuntos(), resultEntity.getPuntos(),0.001);\n }", "protected String getTitoloPaginaMadre() {\n return VUOTA;\n }", "public void ucitajPotez(Potez potez) {\n\t\tint red = potez.vratiRed();\n\t\tint kolona = potez.vratiKolonu();\n\t\ttabla[red][kolona] = potez.vratiRezultat();\n\n\t\tif (potez.vratiRezultat() == Polje1.potopljen) {\n\t\t\tint gornjiRed, gornjaKolona;\n\t\t\tboolean cont1 = false;\n\t\t\tboolean cont2 = false;\n\t\t\tboolean redar = false;\n\t\t\tboolean kolonar = false;\n\t\t\twhile (redar == false) {\n\t\t\t\tif (red == 0) {\n\t\t\t\t\tgornjiRed = 0;\n\t\t\t\t\tcont1 = true;\n\t\t\t\t} else {\n\t\t\t\t\tgornjiRed = red - 1;\n\t\t\t\t}\n\t\t\t\tif (red == 9) {\n\t\t\t\t\tcont2 = true;\n\t\t\t\t}\n\t\t\t\tif (tabla[gornjiRed][kolona] == Polje1.pogodjen && cont1 == false) {\n\t\t\t\t\ttabla[gornjiRed][kolona] = Polje1.potopljen;\n\t\t\t\t\tred--;\n\t\t\t\t} else {\n\t\t\t\t\tcont1 = true;\n\t\t\t\t\tgornjiRed++;\n\t\t\t\t}\n\t\t\t\tif (cont1 == true) {\n\t\t\t\t\tif (tabla[gornjiRed][kolona] == Polje1.pogodjen || tabla[gornjiRed][kolona] == Polje1.potopljen) {\n\t\t\t\t\t\ttabla[gornjiRed][kolona] = Polje1.potopljen;\n\t\t\t\t\t\tred++;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tcont2 = true;\n\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\tif (cont1 == true && cont2 == true)\n\t\t\t\t\tredar = true;\n\t\t\t}\n\t\t\tcont1 = false;\n\t\t\tcont2 = false;\n\t\t\tred = potez.vratiRed();\n\t\t\twhile (kolonar == false) {\n\t\t\t\tif (kolona == 0) {\n\t\t\t\t\tgornjaKolona = 0;\n\t\t\t\t\tcont1 = true;\n\t\t\t\t} else {\n\t\t\t\t\tgornjaKolona = kolona - 1;\n\t\t\t\t}\n\t\t\t\tif (kolona == 9) {\n\t\t\t\t\tcont2 = true;\n\t\t\t\t}\n\t\t\t\tif (tabla[red][gornjaKolona] == Polje1.pogodjen && cont1 == false) {\n\t\t\t\t\ttabla[red][gornjaKolona] = Polje1.potopljen;\n\t\t\t\t\tkolona--;\n\t\t\t\t} else {\n\t\t\t\t\tcont1 = true;\n\t\t\t\t\tgornjaKolona++;\n\t\t\t\t}\n\t\t\t\tif (cont1 == true) {\n\t\t\t\t\tif (tabla[red][gornjaKolona] == Polje1.pogodjen || tabla[red][gornjaKolona] == Polje1.potopljen) {\n\t\t\t\t\t\ttabla[red][gornjaKolona] = Polje1.potopljen;\n\t\t\t\t\t\tkolona++;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tcont2 = true;\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\tif (cont1 == true && cont2 == true)\n\t\t\t\t\tkolonar = true;\n\n\t\t\t}\n\n\t\t}\n\n\n\t}", "public void tampilBuku() {\n System.out.println(\"ID : \" + this.id);\n System.out.println(\"Judul : \" + this.judul);\n System.out.println(\"Tahun Terbit: \" + this.tahun);\n }", "public void asetaTeksti(){\n }", "public String getTiempo() {\r\n return tiempo;\r\n }", "public void klikkaa(Tavarat tavarat, Klikattava klikattava);", "public static void TroskoviPredjenogPuta() {\n\t\tUtillMethod.izlistavanjeVozila();\n\t\tSystem.out.println(\"Unesite redni broj vozila za koje zelite da racunate predjeni put!\");\n\t\tint redniBroj = UtillMethod.unesiteInt();\n\t\tif (redniBroj < Main.getVozilaAll().size()) {\n\t\t\tif (!Main.getVozilaAll().get(redniBroj).isVozObrisano()) {\n\t\t\t\tSystem.out.println(\"Unesite broj kilometara koje ste presli sa odgovarajucim vozilom\");\n\t\t\t\tdouble km = UtillMethod.unesiteBroj();\n\t\t\t\tVozilo v = Main.getVozilaAll().get(redniBroj);\n\t\t\t\tdouble rezultat;\n\t\t\t\tif(v.getGorivaVozila().size()>1) {\n\t\t\t\t\tGorivo g = UtillMethod.izabirGoriva();\n\t\t\t\t\trezultat = cenaTroskaVoz(v,km,g);\n\t\t\t\t}else {\n\t\t\t\t\t rezultat = cenaTroskaVoz(v,km,v.getGorivaVozila().get(0));\n\t\t\t\t}\n\t\t\t\tSystem.out.println(\"Cena troskova za predjeni put je \" + rezultat + \"Dinara!\");\n\t\t\t} else {\n\t\t\t\tSystem.out.println(\"Ovo vozilo je obrisano i ne moze da se koristi!\");\n\t\t\t}\n\t\t} else {\n\t\t\tSystem.out.println(\"Uneli ste pogresan redni broj!\");\n\t\t}\n\t}", "private void kasvata() {\n T[] uusi = (T[]) new Object[this.arvot.length * 3 / 2 + 1];\n for (int i = 0; i < this.arvot.length; i++) {\n uusi[i] = this.arvot[i];\n }\n this.arvot = uusi;\n }", "public void tulostaKomennot() {\n this.io.tulostaTeksti(\"Komennot: \");\n for (int i = 1; i <= this.komennot.keySet().size(); i++) {\n this.io.tulostaTeksti(this.komennot.get(i).toString());\n }\n this.io.tulostaTeksti(\"\");\n }", "@Override\r\n\tpublic TVA mettreAjourTVA(TVA t) {\n\t\treturn null;\r\n\t}", "private String elaboraIncipit() {\n String testo = VUOTA;\n\n if (usaHeadIncipit) {\n testo += elaboraIncipitSpecifico();\n testo += A_CAPO;\n }// fine del blocco if\n\n return testo;\n }", "protected String elaboraIncipitSpecifico() {\n return VUOTA;\n }", "public Tarea(String descripcionTarea)\n {\n //Añade la descripción de la tarea\n descripcion = descripcionTarea;\n tareaCompletada = false;\n //Por defecto, las tareas tienen prioridad 0\n prioridad = 0;\n //Las nuevas tareas no tienen fecha de vencimiento\n fechaVencimiento = null;\n }", "public void ordenaPontos(){\r\n\t\tloja.ordenaPontos();\r\n\t}", "public TipoPrestamo() {\n\t\tsuper();\n\t}", "public String getNombreTI() {\n return this.nombreTI;\n }", "@Override\n public String getGenericLabel() {\n return \"Počet sloupců v každé tabulce\";\n }", "public static void dodavanjeTeretnogVozila() {\n\t\tString vrstaVozila = \"Teretno Vozilo\";\n\t\tString regBr = UtillMethod.unosRegBroj();\n\t\tGorivo gorivo = UtillMethod.izabirGoriva();\n\t\tGorivo gorivo2 = UtillMethod.izabirGorivaOpet(gorivo);\n\t\tint brServisa = 1;\n\t\tdouble potrosnja = UtillMethod.unesiteDoublePotrosnja();\n\t\tSystem.out.println(\"Unesite broj km koje je vozilo preslo:\");\n\t\tdouble predjeno = UtillMethod.unesiteBroj();\n\t\tdouble preServisa = 20000;\n\t\tdouble cenaServisa = 10000;\n\t\tSystem.out.println(\"Unesite cenu vozila za jedan dan:\");\n\t\tdouble cenaDan = UtillMethod.unesiteBroj();\n\t\tSystem.out.println(\"Unesite broj sedista u vozilu:\");\n\t\tint brSedista = UtillMethod.unesiteInt();\n\t\tSystem.out.println(\"Unesite broj vrata vozila:\");\n\t\tint brVrata = UtillMethod.unesiteInt();\n\t\tboolean vozObrisano = false;\n\t\tArrayList<Gorivo> gorivaVozila = new ArrayList<Gorivo>();\n\t\tgorivaVozila.add(gorivo);\n\t\tif(gorivo2!=Main.nista) {\n\t\t\tgorivaVozila.add(gorivo2);\n\t\t}\n\t\tArrayList<Servis> servisiNadVozilom = new ArrayList<Servis>();\n\t\tSystem.out.println(\"Unesite maximalnu masu koje vozilo moze da prenosi u KG !!\");\n\t\tint maxMasauKg = UtillMethod.unesiteInt();\n\t\tSystem.out.println(\"Unesite maximalnu visinu u m:\");\n\t\tdouble visinauM = UtillMethod.unesiteBroj();\n\t\tTeretnaVozila vozilo = new TeretnaVozila(vrstaVozila, regBr, gorivaVozila, brServisa, potrosnja, predjeno, preServisa,\n\t\t\t\tcenaServisa, cenaDan, brSedista, brVrata, vozObrisano, servisiNadVozilom, maxMasauKg, visinauM);\n\t\tUtillMethod.prviServis(vozilo, predjeno);\n\t\tMain.getVozilaAll().add(vozilo);\n\t\tSystem.out.println(\"Novo vozilo je uspesno dodato u sistem!\");\n\t\tSystem.out.println(\"--------------------------------------\");\n\t}", "private String elaboraAvvisoScrittura() {\n String testo = VUOTA;\n\n if (usaHeadNonScrivere) {\n testo += TAG_NON_SCRIVERE;\n testo += A_CAPO;\n }// end of if cycle\n\n return testo;\n }", "public void presenta_Estudiante(){\r\n System.out.println(\"Universidad Técnica Particular de Loja\\nInforme Semestral\\nEstudiante: \"+nombre+\r\n \"\\nAsignatura: \"+nAsignatura+\"\\nNota 1 Bimestre: \"+nota1B+\"\\nNota 2 Bimestre: \"+nota2B+\r\n \"\\nPromedio: \"+promedio()+\"\\nEstado de la Materia: \"+estado());\r\n }", "public void primerPunto() {\n\t\tp = new PuntoAltaPrecision(this.xCoord, this.yCoord);\n\t\t// Indicamos la trayectoria por la que va la pelota\n\t\tt = new TrayectoriaRecta(1.7f, p, false);\n\t}", "@Override\n public void cantidad_Ataque(){\n ataque=5+2*nivel+aumentoT;\n }", "public void setTiempo(String tiempo) {\r\n this.tiempo = tiempo;\r\n }", "public String getPoruka() {\r\n\treturn \"poruka\";\r\n\t}", "private void atualizarTela() {\n\t\tif(this.primeiraJogada == true) {//SE FOR A PRIMEIRA JOGADA ELE MONTA O LABEL DOS NUMEROS APOS ESCOLHER A POSICAO PELA PRIMEIRA VEZ\r\n\t\t\tthis.primeiraJogada = false;\r\n\t\t\tthis.montarLabelNumeros();\r\n\t\t}\r\n\r\n\t\tthis.esconderBotao();\r\n\t\t\r\n\t\tthis.acabarJogo();\r\n\t}", "public static void trazenjeVozila(Iznajmljivac o) {\n\t\tLocalDate pocetniDatum = UtillMethod.unosDatum(\"pocetni\");\n\t\tLocalDate krajnjiDatum = UtillMethod.unosDatum(\"krajnji\");\n\t\tSystem.out.println(\"------------------------------------\");\n\t\tSystem.out.println(\"Provera dostupnosti vozila u toku...\\n\");\n\t\tArrayList<Vozilo> dostupnaVoz = new ArrayList<Vozilo>();\n\t\tint i = 0;\n\t\tfor (Vozilo v : Main.getVozilaAll()) {\n\t\t\tif (!postojiLiRezervacija(v, pocetniDatum, krajnjiDatum) && !v.isVozObrisano()) {\n\t\t\t\tSystem.out.println(i + \"-\" + v.getVrstaVozila() + \"-\" + \"Registarski broj\" + \"-\" + v.getRegBR()\n\t\t\t\t\t\t+ \"-Potrosnja na 100km-\" + v.getPotrosnja100() + \"litara\");\n\t\t\t\ti++;\n\t\t\t\tdostupnaVoz.add(v);\n\t\t\t}\n\t\t}\n\t\tif (i > 0) {\n\t\t\tSystem.out.println(\"------------------------------------------------\");\n\t\t\tSystem.out.println(\"Ukucajte kilometrazu koju planirate da predjete:\");\n\t\t\tdouble km = UtillMethod.unesiteBroj();\n\t\t\tint km1 = (int) km;\n\t\t\tporedjenjeVozila d1 = new poredjenjeVozila(km1);\n\t\t\tCollections.sort(dostupnaVoz,d1);\n\t\t\tint e = 0;\n\t\t\tfor(Vozilo v : dostupnaVoz) {\n\t\t\t\tdouble temp = cenaTroskaVoz(v, km, v.getGorivaVozila().get(0));\n\t\t\t\tSystem.out.println(e + \" - \" + v.getVrstaVozila()+ \"-Registarski broj: \"+ v.getRegBR()+\" | \"+ \"Cena na dan:\"+v.getCenaDan() +\" | Broj sedista:\"+ v.getBrSedist()+ \" | Broj vrata:\"+ v.getBrVrata() + \"| Cena troskova puta:\" + temp + \" Dinara\");\n\t\t\t\te++;\n\t\t\t}\n\t\t\tSystem.out.println(\"---------------------------------------\");\n\t\t\tSystem.out.println(\"Unesite redni broj vozila kojeg zelite:\");\n\t\t\tint redniBroj = UtillMethod.unesiteInt();\n\t\t\tif (redniBroj < dostupnaVoz.size()) {\n\t\t\t\tDateTimeFormatter formatters = DateTimeFormatter.ofPattern(\"dd/MM/yyyy\");\n\t\t\t\tString pocetni = pocetniDatum.format(formatters);\n\t\t\t\tString krajnji = krajnjiDatum.format(formatters);\n\t\t\t\tdouble cena = UtillMethod.cenaIznaj(pocetniDatum, krajnjiDatum, dostupnaVoz.get(redniBroj));\n\t\t\t\tRezervacija novaRez = new Rezervacija(dostupnaVoz.get(redniBroj), o, cena, false, pocetni, krajnji);\n\t\t\t\tMain.getRezervacijeAll().add(novaRez);\n\t\t\t\tSystem.out.println(\"Uspesno ste napravili rezervaciju!\");\n\t\t\t\tSystem.out.println(\"---------------------------------\");\n\t\t\t\tSystem.out.println(novaRez);\n\t\t\t\tSystem.out.println(\"---------------------------------\");\n\t\t\t} else {\n\t\t\t\tSystem.out.println(\"Uneli ste pogresan redni broj!\");\n\t\t\t}\n\t\t} else {\n\t\t\tSystem.out.println(\"Nema dostupnih vozila za rezervaaciju.\");\n\t\t}\n\t}", "public Tabla(int tip) {\n\t\tthis.sirinaTable = 20;\n\t\tthis.visinaTable = 20;\n\t\tthis.tip = tip;\n\t\tthis.tabla = new char[20][20];\n\t\tfor (int i = 0; i < this.visinaTable;i++) {\n\t\t\tfor (int j = 0; j < this.sirinaTable;j++) {\n\t\t\t\ttabla[i][j] = '.';\n\t\t\t}\n\t\t}\n\t\trezultat = 0;\n\t\tzmija = new ArrayList<Cvor>();\n\t\t\n\t\tif (tip == 2) {\n\t\t\tthis.dodajZidove();\n\t\t}\n\t\telse if(tip == 3) {\n\t\t\tthis.dodajPrepreke1();\n\t\t}\n\t\telse if(tip == 4) {\n\t\t\tthis.dodajPrepreke2();\n\t\t}\n\t\tthis.dodajZmijuPocetak();\n\t\tthis.dodajHranu();\n\t\tthis.smjer = 'd';\n\t}", "private String tallenna() {\n Dialogs.showMessageDialog(\"Tallennetaan!\");\n try {\n paivakirja.tallenna();\n return null;\n } catch (SailoException ex) {\n Dialogs.showMessageDialog(\"Tallennuksessa ongelmia!\" + ex.getMessage());\n return ex.getMessage();\n }\n }", "public Transportadora() {\r\n super();\r\n this.nif = \"\";\r\n this.raio = 0;\r\n this.precoKm = 0;\r\n this.classificacao = new Classificacao();\r\n this.estaLivre = true;\r\n this.velocidadeMed = 0;\r\n this.kmsTotal = 0;\r\n this.capacidade = 0;\r\n }", "public void PedirSintomas() {\n\t\t\r\n\t\tSystem.out.println(\"pedir sintomas del paciente para relizar el diagnosticoa\");\r\n\t}", "private String nalozZvieraNaVozidlo() {\r\n if (zoo.getPracovneVozidlo() == null) {\r\n return \"Pracovne vozidlo nie je pristavene\";\r\n }\r\n\r\n Integer pozicia = MojeMetody.vlozInt(\"Vloz cislo zvierata\");\r\n if (pozicia == null) return \"\";\r\n\r\n try {\r\n Prepravitelny z = (Prepravitelny) zoo.getZvierataZOO(pozicia - 1);\r\n zoo.nalozZivocicha(z);\r\n zoo.odstranZivocicha(pozicia - 1);\r\n return \"Zviera \" + z + \"\\n\\tbolo nalozene na prepravne vozidlo\";\r\n } catch (ClassCastException exCC) {\r\n return \"Zviera c. \" + pozicia + \" nemozno prepravit\\n\\t\";\r\n } catch (NullPointerException exNP) {\r\n return \"Zviera c. \" + pozicia + \" nie je v ZOO\";\r\n } catch (Exception ex) {\r\n return \"Neznama chyba:\\n\\t\" + ex;\r\n }\r\n }", "private void popuniTabelu() {\n try {\n List<PutnikEntity> putnici=Controller.vratiSvePutnike();\n TableModel tm=new PutnikTableModel(putnici);\n jtblPutnici.setModel(tm);\n } catch (Exception ex) {\n Logger.getLogger(FIzaberiLet.class.getName()).log(Level.SEVERE, null, ex);\n }\n }", "public RisultatiRicercaStampaAllegatoAttoModel() {\n\t\tsuper();\n\t\tsetTitolo(\"Risultati di ricerca stampe allegato atto\");\n\t}", "@Override\n public void cantidad_Punteria(){\n punteria=69.5+05*nivel+aumentoP;\n }", "public JogadorTradutor() {\n this.nome= \"Sem Registro\";\n this.pontuacao = pontuacao;\n id = id;\n \n geradorDesafioItaliano = new GerarPalavra(); // primeira palavra ja é gerada para o cliente\n }", "@Override\n\tpublic String getTareas() {\n\t\treturn \"TAREA COMERCIAL 3: VENDE MUCHO TODOS LOS DÍAS\";\n\t}", "@RequestMapping(\"/pegawai/termuda-tertua\")\n\tprivate String viewPegawaiTermudaTertua(@RequestParam(value = \"id\") long id, Model model) {\n\t\tInstansiModel instansi = instansiService.getInstansiDetailById(id);\n\t\tList<PegawaiModel> pegawaiList = instansi.getListPegawaiInstansi();\n\t\t\n\t\tPegawaiModel pegawaiTua = new PegawaiModel();\n\t\tPegawaiModel pegawaiMuda= new PegawaiModel();\n\t\t\n\t\tint muda = 2018;\n\t\tint tua= 0;\n\t\tfor(PegawaiModel pegawai : pegawaiList) {\n\t\t\tint tempUsia = pegawai.getUsia();\n\t\t\tif(tempUsia < muda) {\n\t\t\t\tmuda = tempUsia;\n\t\t\t\tpegawaiMuda = pegawai;\n\t\t\t}\n\t\t\t\n\t\t\tif(tempUsia > tua) {\n\t\t\t\ttua = tempUsia;\n\t\t\t\tpegawaiTua = pegawai;\n\t\t\t}\n\t\t}\n\n\t\tmodel.addAttribute(\"pegawaiTermuda\", pegawaiMuda);\n\t\tmodel.addAttribute(\"pegawaiTertua\", pegawaiTua);\n\t\tmodel.addAttribute(\"gajiTermuda\", pegawaiMuda.getGaji());\n\t\tmodel.addAttribute(\"gajiTertua\", pegawaiTua.getGaji());\n\t\treturn \"view-pegawai-tua-muda\";\n\t}", "@Override\n\tpublic long getCodTecnico() {\n\t\treturn model.getCodTecnico();\n\t}", "public String getPoruka() {\r\n\t\t//2.greska \"poruka\"\r\n\treturn poruka;\r\n\t}", "@Override\n\tpublic String dohvatiKontakt() {\n\t\treturn \"Naziv tvrtke: \" + naziv + \", mail: \" + getEmail() + \", tel: \" + getTelefon() + \", web: \" + web;\n\t}", "@Override\n public String toString() {\n return tla;\n }", "public Tavolo (String id_tavolo, int num_posti){\n this.id_tavolo = id_tavolo;\n this.num_posti = num_posti;\n interno = true;\n disponibile = true;\n AssegnamentiTavolo = new ArrayList<Invitato>(num_posti);\n postiTot=num_posti;\n }", "public abstract String dohvatiKontakt();", "public void tiepTucNhap() {\n\t\tlog.info(\"-----tiepTucNhap()-----\");\n\t\tlog.info(String.format(\"-----index: %s\", updateItem));\n\t\t\n\t\tlog.info(\"tonkhoMa:\"+tonkhoMa);\n\t\tlog.info(\"xuat:\"+xuat);\n\t\tlog.info(\"dmtMa:\"+dmtMa);\n\t\tlog.info(\"updateItem:\"+updateItem);\n\t\tlog.info(\"tonkho:\"+tonkho);\n\n\t\tif (xuat == null || xuat.equals(\"\") || tonkho == null || tonkho.equals(\"\")){\n\t\t\treturn;\n\t\t}\n\t\t \n\t\tif (\"\".equals(tonkhoMa) && tonkhoMa == null) {\n\t\t\tlog.info(\"-----tonkho ma is null.\");\n\t\t} else {\n\t\t\tlog.info(String.format(\"-----tonkho ma: %s\", tonkhoMa));\n\t\t\tTonKho tk = null;\n\t\t\t\n\t\t\tTonKhoDelegate tkDelegate;\n\t\t\ttry {\n\t\t\t\ttkDelegate = TonKhoDelegate.getInstance();\n\t\t\t\t\n\t\t\t\ttk = tkDelegate.find(Integer.valueOf(tonkhoMa));\n\t\t\t} catch (Exception e) {\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t\t\n\t\t\tCtTraKho ctx = new CtTraKho();\n\t\t\t\n\t\t\tDouble slXuat = new Double(\"0\");\n\t\t\tfor (int i = 0; i < listCtKhoLeTraEx.size(); i++) {\n\t\t\t\tCtTraKho ctxk = listCtKhoLeTraEx.get(i).getCtTraKho();\n\t\t\t\tif (malk.equals(ctxk.getCttrakhoMalk())) {\n\t\t\t\t\tlog.info(\"-----malk \" + malk);\n\t\t\t\t\tslXuat += ctxk.getCttrakhoSoluong();\n\t\t\t\t\tupdateItem = i;\n\t\t\t\t}\n\t\t\t}\n\t\t\tslXuat += Double.valueOf(xuat);\n\t\t\tctx.setCttrakhoSoluong(slXuat);\n\t\t\tCtTraKhoExt ctxEx = createCtXuatKho(ctx, tk);\n\t\t\tlog.info(\"-----xuat: \" + slXuat);\n\t\t\t\n\t\t\tif (updateItem.equals(-1)) {\n\t\t\t\tlog.info(\"-----them moi ct\");\n\t\t\t\tlistCtKhoLeTraEx.add(ctxEx);\n\t\t\t} else {\n\t\t\t\tlog.info(\"-----Cap nhat ct-----\");\n\t\t\t\tif (tk != null) {\n\t\t\t\t\tlistCtKhoLeTraEx.set(updateItem, ctxEx);\n\t\t\t\t} else {\n\t\t\t\t\tFacesMessages.instance().add(IConstantsRes.PHIEUXUATKHO_TK_NULL, dmtMa);\n\t\t\t\t}\n\n\t\t\t\tlog.info(String.format(\"-----update ct: %s\", ctx.getCttrakhoThutu()));\n\t\t\t}\n\n\t\t\tcount = listCtKhoLeTraEx.size();\n\t\t\tlog.info(String.format(\"-----listCtXuatKho: %s\", listCtKhoLeTraEx.size()));\n\t\t\ttonkhoMa = \"\";\n\t\t\tdmtMa = \"\";\n\t\t\ttonkho = new Double(0);\n\t\t\txuat = new Double(0);\n\t\t\tupdateItem = -1;\n\t\t}\n\t\ttinhTien();\n\t}", "private void srediTabelu() {\n\n mtu = (ModelTabeleUlica) jtblUlica.getModel();\n ArrayList<Ulica> ulice = kontrolor.Kontroler.getInstanca().vratiUlice();\n mtu.setLista(ulice);\n\n }", "public TipoUsuario getTipousuario() {\n return tipousuario;\n }", "public void obliczSzanseWykolejenia(Tramwaj tramwaj, Pogoda pogoda, Motorniczy motorniczy, Przystanek przystanek){\r\n RegulyWykolejen regulyWykolejen= new RegulyWykolejen();\r\n this.szansaWykolejenia = pogoda.getRyzyko() + przystanek.getStanTechnicznyPrzystanku() + tramwaj.getStanTechTramwaju() + regulyWykolejen.regulaWiek(motorniczy.getWiek()) + regulyWykolejen.regulaDoswiadczenie(motorniczy.getDoswiadczenie());\r\n }", "@Override\r\n\tpublic String getOstatu_mota() {\n\t\treturn super.getOstatu_mota();\r\n\t}", "protected String elaboraIncipitSpecificoSottopagina(String soggettoSottopagina) {\n return VUOTA;\n }", "Kerucut(){\r\n Tabung tab = new Tabung();\r\n tinggi=tab.getTinggi();\r\n }", "private String creaElenco() {\n String testoTabella ;\n String riga = CostBio.VUOTO;\n ArrayList listaPagine = new ArrayList();\n ArrayList listaRiga;\n HashMap mappaTavola = new HashMap();\n String cognomeText;\n int num;\n int taglioPagine = Pref.getInt(CostBio.TAGLIO_COGNOMI_PAGINA);\n String tag = \"Persone di cognome \";\n ArrayList titoli = new ArrayList();\n titoli.add(LibWiki.setBold(\"Cognome\"));\n titoli.add(LibWiki.setBold(\"Voci\"));\n\n for (Map.Entry<String, Integer> mappa: mappaCognomi.entrySet()) {\n\n cognomeText = mappa.getKey();\n num = mappa.getValue();\n if (num >= taglioPagine) {\n cognomeText = tag + cognomeText + CostBio.PIPE + cognomeText;\n cognomeText = LibWiki.setQuadre(cognomeText);\n cognomeText = LibWiki.setBold(cognomeText);\n }// end of if cycle\n\n listaRiga = new ArrayList();\n listaRiga.add(cognomeText);\n listaRiga.add(num);\n listaPagine.add(listaRiga);\n\n }// end of for cycle\n mappaTavola.put(Cost.KEY_MAPPA_SORTABLE_BOOLEAN, true);\n mappaTavola.put(Cost.KEY_MAPPA_TITOLI, titoli);\n mappaTavola.put(Cost.KEY_MAPPA_RIGHE_LISTA, listaPagine);\n testoTabella = LibWiki.creaTable(mappaTavola);\n\n return testoTabella;\n }", "String getTitolo();", "public static void pocetniMeni() {\r\n\t\tSystem.out\r\n\t\t\t\t.println(\"***********************************************\\n\"\r\n\t\t\t\t\t\t+ \"Unesite 1 ako zelite vidjeti kalendar(za dati mjesec i godinu)\\n\"\r\n\t\t\t\t\t\t+ \"Unesite 2 za pregled podsjetnika za dati mjesec i godinu\\n\"\r\n\t\t\t\t\t\t+ \"Unesite 3 da pregledate podsjetnik za datu godinu\\n\"\r\n\t\t\t\t\t\t+ \"Unesite 4 ako zelite da pogledate sve podsjetnike!\\n\"\r\n\t\t\t\t\t\t+ \"Unesite 5 ako zelite da upisete neki podsjetnik!\\n\"\r\n\t\t\t\t\t\t+ \":::::::::::::::::::::::::::::::::::::::::::::::\");\r\n\t}", "public String getInfoTitulos(){\r\n String infoTitulos = \"\";\r\n \r\n if(this.propriedadesDoJogador.size() > 0 || this.companhiasDoJogador.size() > 0){\r\n for(int i = 0; i < this.propriedadesDoJogador.size(); i++){\r\n infoTitulos += propriedadesDoJogador.get(i).getDescricao()+\"\\n\";\r\n }\r\n for(int i = 0; i < this.companhiasDoJogador.size(); i++){\r\n infoTitulos += companhiasDoJogador.get(i).getDescricao()+\"\\n\";\r\n }\r\n return infoTitulos;\r\n \r\n }else{\r\n return \"Você não possui títulos\";\r\n }\r\n }", "public void ustawPojazdNaPoczatek()\n\t{\n\t\tSciezka pierwszaSc = droga.get(0);\n\t\tfinal double y = 10;\n\t\tpojazd.zmienPozycje(pierwszaSc.getCenterDownX(), y);\n\t}", "public TTau() {}", "private void peliLoppuuUfojenTuhoamiseen() {\n if (tuhotut == Ufolkm) {\n ingame = false;\n Loppusanat = \"STEVE HOLT!\";\n }\n }", "private static void statistique(){\n\t\tfor(int i = 0; i<7; i++){\n\t\t\tfor(int j = 0; j<7; j++){\n\t\t\t\tfor(int l=0; l<jeu.getJoueurs().length; l++){\n\t\t\t\t\tif(jeu.cases[i][j].getCouleurTapis() == jeu.getJoueurs()[l].getNumJoueur()){\n\t\t\t\t\t\tjeu.getJoueurs()[l].setTapis(jeu.getJoueurs()[l].getTapisRest()+1);\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tJoueur j;\n\t\tSystem.out.println(\"// Fin de la partie //\");\n\t\tfor(int i=0; i<jeu.getJoueurs().length; i++) {\n\t\t\tj =jeu.getJoueurs()[i];\n\t\t\tSystem.out.println(\"Joueur \"+ (j.getNumJoueur()+1) + \" a obtenue \"+j.getTapisRest()+j.getMonnaie()+\" points\" );\n\t\t}\n\t}", "public String getPuntoEmision()\r\n/* 124: */ {\r\n/* 125:207 */ return this.puntoEmision;\r\n/* 126: */ }", "public Torretta1(int danno, int x, int y, ArrayList<Proiettile> proiettili) {\r\n super();\r\n velocitàAttacco = 5000;\r\n attacco = danno;\r\n this.proiettili = proiettili;\r\n this.x = x * 40;\r\n this.y = y * 40 - 40;\r\n range = new Ellipse2D.Double();\r\n range.setFrame(this.x - 40, this.y - 40, 119, 119);\r\n temposparo = 200;\r\n finestrasparo = 0;\r\n costoAcquisto = 10;\r\n tipo='a';\r\n }", "@Test\n public void testAvaaRuutu() {\n int x = 0;\n int y = 0;\n Peli pjeli = new Peli(new Alue(3, 0));\n pjeli.avaaRuutu(x, y);\n ArrayList[] lista = pjeli.getAlue().getRuudukko();\n ArrayList<Ruutu> ruudut = lista[0];\n assertEquals(true, ruudut.get(0).isAvattu());\n assertEquals(false, pjeli.isLahetetty());\n }", "public void atacar(Pokemon t){\n\tif(t.obtenerTipo()==tipoPokeMasDano){\n\t dano*=2;\n\t System.out.println(\"El ataque se hace más fuerte contra este tipo de Pokemon\");\n\t}\n\tSystem.out.println(\"Has ejecutado \"+obtenerNombreAtaque()+\"\\nEl ataque le causa un daño de \"+obtenerDano()+\" a \"+\n\t\t\t t.obtenerApodo()+\":\\n\"+obtenerDescripcionAtaque());\n\tt.puntosVida-=dano;\n\tcontadorNivel++;\n\tSystem.out.println(\"Los puntos de vida restantes de \"+t.obtenerApodo()+\" son \" +t.obtenerPuntosVida());\n }", "@Test\n public void yksiVasemmalle() {\n char[][] kartta = Labyrintti.lueLabyrintti(\"src/main/resources/labyrinttiTestiVasen.txt\");\n assertFalse(kartta == null);\n Labyrintti labyrintti = new Labyrintti(kartta);\n RatkaisuLeveyshaulla ratkaisuSyvyyshaulla = new RatkaisuLeveyshaulla(labyrintti);\n String ratkaisu = ratkaisuSyvyyshaulla.ratkaisu();\n assertTrue(Tarkistaja.tarkista(ratkaisu, labyrintti));\n }", "public void sumaPuntos() {\r\n int rojo = 0;\r\n int azul = 0;\r\n for (int i = 1; i < 10; i++) {\r\n\r\n if (tablero[1][i].getTipo().equals(\"Rojo\")) {\r\n rojo += tablero[1][i].getValor();\r\n }\r\n\r\n if (tablero[8][i].getTipo().equals(\"Azul\")) {\r\n azul += tablero[8][i].getValor();\r\n }\r\n\r\n }\r\n if (rojo > azul) {\r\n this.setResultado(\"Rojo\");\r\n this.agregarVictoria(jugadorRojo);\r\n }\r\n if (azul > rojo) {\r\n this.setResultado(\"Azul\");\r\n this.agregarVictoria(jugadorAzul);\r\n }\r\n \r\n this.setReplay(true);\r\n }", "public void tampilKarakterA(){\r\n System.out.println(\"Saya mempunyai kaki empat \");\r\n }", "@Override\n\tpublic void trabajar() {\n\n\t}", "public void niveauSuivant() {\n niveau = niveau.suivant();\n }", "public String getPoruka() {\r\n\treturn poruka;\r\n\t}", "private int generujViacZvierat(int pocet){\r\n int poc = 0;\r\n for (int i = 0; i < pocet; i++) {\r\n if (zoo.pridajZivocicha(vytvorZivocicha())) poc++;\r\n }\r\n return poc;\r\n }", "static void cetak_data(String nama, int usia) {\n int tahun_sekarang = 2020, tahun_lahir = tahun_sekarang - usia;\r\n System.out.println(\"---------\\nNama Saya : \" + nama + \"\\nUsia Saya : \" + usia + \"\\nTahun Lahir : \" + tahun_lahir);\r\n }", "@SuppressWarnings(\"unchecked\")\n\tpublic void funkcie() {\n\t\tTableColumn<Znamka, String> datumColumn = new TableColumn<>(\"Datum pisomky\");\n\t\tdatumColumn.setMinWidth(velkostPolickaX - 1);\n\t\tdatumColumn.setCellValueFactory(new PropertyValueFactory<>(\"datumS\"));\n\n\t\tTableColumn<Znamka, Double> hodnotaColumn = new TableColumn<Znamka, Double>(\"Hodnota\");\n\t\thodnotaColumn.setMinWidth(velkostPolickaX - 1);\n\t\thodnotaColumn.setCellValueFactory(new PropertyValueFactory<>(\"hodnotaS\"));\n\n\t\tTableColumn<Znamka, Double> maxHodnotaColumn = new TableColumn<Znamka, Double>(\"Max. Hodnota\");\n\t\tmaxHodnotaColumn.setMinWidth(velkostPolickaX - 1);\n\t\tmaxHodnotaColumn.setCellValueFactory(new PropertyValueFactory<>(\"maxHodnotaS\"));\n\n\t\ttabulkaZiak.getColumns().addAll(hodnotaColumn, maxHodnotaColumn, datumColumn);\n\n\t\tvyberPredmetov.setItems(((Ziak) aktualnyPouzivatel).vratMenoPredmetov());\n\t\tvyberPredmetov.getSelectionModel().selectedIndexProperty()\n\t\t\t\t.addListener((ChangeListener<Number>) (ov, value, new_value) -> {\n\t\t\t\t\ttabulkaZiak.setItems(((Ziak) aktualnyPouzivatel).vratZnamkyPredmetu((int) new_value));\n\t\t\t\t});\n\t\tvyberPredmetov.getSelectionModel().selectFirst();\n\t}", "public int getTipusPartida() {\r\n\t\treturn tipus;\r\n\t}", "public Utilizador(){\n this.email = \"\";\n this.password = \"\";\n this.nome = \"\";\n this.genero = \"\";\n this.morada = \"\";\n this.data_nasc = new GregorianCalendar();\n this.data_reg = new GregorianCalendar();\n this.amigos = new TreeSet<>();\n this.pedido_amizade = new TreeSet<>();\n this.atividades = new HashMap<>();\n this.eventos = new TreeSet<>();\n }", "public String dimeTuTiempo()\n {\n String cadResultado=\"\";\n if (horas<10)\n {\n cadResultado=cadResultado+\"0\";\n }\n cadResultado=cadResultado+horas;\n cadResultado=cadResultado+\":\";\n if(minutos<10)\n {\n cadResultado=cadResultado+\"0\";\n }\n cadResultado=cadResultado+minutos;\n \n return cadResultado;\n }", "public Puertas(String via, int iden, int tipo){\r\n this.viaje=via;\r\n this.identi=iden;\r\n this.tipoPriori=tipo;\r\n switch(tipo){\r\n case(1):\r\n this.namePriori=\"Oro\";\r\n break;\r\n case(2):\r\n this.namePriori=\"Platino\";\r\n break;\r\n case(3):\r\n this.namePriori=\"Especial\";\r\n break;\r\n case(4):\r\n this.namePriori=\"Económico\";\r\n break;\r\n default:\r\n this.namePriori=\"\";\r\n break;\r\n } \r\n }", "private Tarea recuperarPrimerTarea(String nombre, SimpleNode nodoRaiz) {\n\t\t// dejamos lista la primer tarea en el planificador\n\t\tTarea tarea = new Tarea();\n\t\ttarea.setNombre(nombre);\n\t\ttarea.setNodos(nodoRaiz);\n\t\ttarea.setContexto(SimpleNode.inicializaTablaDeSimbolos());\n\n\t\treturn tarea;\n\n\t}", "protected int getTreinAantal(){\r\n return treinaantal;\r\n }", "@Override\n\tpublic String getInformeVendedor() {\n\t\treturn \"Informe trimestre 3\";\n\t}", "private TipoAtaque generateTipoAtaque() {\n\t\treturn null;\r\n\t}", "private static void dodajClanaUTabelu(Clan c) {\r\n\t\tDefaultTableModel dtm = (DefaultTableModel) teretanaGui.getTable().getModel();\r\n\t\tdtm.addRow(new Object[] { c.getBrojClanskeKarte(), c.getIme(), c.getPrezime(), c.getPol() });\r\n\t\tcentrirajTabelu();\r\n\t}", "public void dodajZmijuPocetak() {\n\t\tthis.zmija.add(new Cvor(1,4));\n\t\tthis.zmija.add(new Cvor(1,3));\n\t\tthis.zmija.add(new Cvor(1,2));\n\t\t\n\t\tint i = this.zmija.get(0).i;\n\t\tint j = this.zmija.get(0).j;\n\t\tthis.tabla[i][j] = 'O';\n\t\t\n\t\tfor (int k = 1; k < this.zmija.size(); k++) {\n\t\t\ti = this.zmija.get(k).i;\n\t\t\tj = this.zmija.get(k).j;\n\t\t\tthis.tabla[i][j] = 'o';\n\t\t}\t\n\t}", "@Override\r\n\tpublic double getPesoTeorico() {\r\n\r\n\t\treturn anamnese.getAltura() * anamnese.getAltura() * 22.0;\r\n\t}", "public void printTagihanTamu() {\n for (Tagihan t: daftarTagihan.values()) {\n System.out.println(\"Tamu:\"+t.tamu.nama);\n System.out.println(\"Tagihan:\"+t.hitungSemuaTagihan());\n }\n }", "private void laskeMatkojenPituus() {\n matkojenpituus = 0.0;\n\n for (Matka m : matkat) {\n matkojenpituus += m.getKuljettumatka();\n }\n\n }", "@Test\n public void tilimaksuKutsuuTilisiirtoaOikeillaParametreilla() {\n when(this.varasto.saldo(1)).thenReturn(10);\n when(this.varasto.haeTuote(1)).thenReturn(new Tuote(1, \"maito\", 5));\n \n this.kauppa.aloitaAsiointi();\n this.kauppa.lisaaKoriin(1);\n this.kauppa.tilimaksu(\"johannes\", \"12345\");\n verify(this.pankki).tilisiirto(eq(\"johannes\"), anyInt(), eq(\"12345\"), anyString(), eq(5));\n \n }", "private void utvidtabellen() {\n\t\tCD[] hjelpeTab;\n\t\tif (cdTabell.length == 0) {\n\t\t\thjelpeTab = new CD[1];\n\t\t\tmaksAntall = 1;\n\t\t} else {\n\t\t\thjelpeTab = new CD[(int) Math.ceil(cdTabell.length * 1.1)];\n\t\t\tmaksAntall = hjelpeTab.length;\n\t\t}\n\t\tfor (int i = 0; i < cdTabell.length; i++) {\n\t\t\thjelpeTab[i] = cdTabell[i];\n\t\t}\n\t\tcdTabell = hjelpeTab;\n\t}", "public void skrivUt(){\n System.out.println(this.fornavn + \" \" + this.etternavn + \" \" + this.adresse + \" \" + this.telefonnr + \" \" + this.alder);\n }", "@Override\n protected String elaboraBody() {\n String text = CostBio.VUOTO;\n int numCognomi = mappaCognomi.size();\n int numVoci = Bio.count();\n int taglioVoci = Pref.getInt(CostBio.TAGLIO_NOMI_ELENCO);\n\n text += A_CAPO;\n text += \"==Cognomi==\";\n text += A_CAPO;\n text += \"Elenco dei \";\n text += LibWiki.setBold(LibNum.format(numCognomi));\n text += \" cognomi '''differenti''' utilizzati nelle \";\n text += LibWiki.setBold(LibNum.format(numVoci));\n text += \" voci biografiche con occorrenze maggiori di \";\n text += LibWiki.setBold(taglioVoci);\n text += A_CAPO;\n text += creaElenco();\n text += A_CAPO;\n\n return text;\n }", "public Personnage attaqueSurPersonnage() {\n\t\tdouble rand = Math.random();\n\t\t\tif (rand >= 0.85){\n\t\t\t\tfrappeMonstre = monstre.getCaracter().getForce() * 2;\n\t\t\t\tjoueur.setDiminutionPV(frappeMonstre);\n\t\t\t\tsetVictimeKO(joueur);\n\t\t\t\tetatAttaque = 'C';\n\t\t\t\treturn joueur;\n\t\t\t}\n\t\t\telse if ((rand < 0.85) && (rand >= 0.15)){\n\t\t\t\tfrappeMonstre = monstre.getCaracter().getForce();\n\t\t\t\tjoueur.setDiminutionPV(frappeMonstre);\n\t\t\t\tsetVictimeKO(joueur);\n\t\t\t\tetatAttaque = 'N';\n\t\t\t\treturn joueur;\n\t\t\t}\n\t\t\telse{\n\t\t\t\tetatAttaque = 'F';\n\t\t\t\tfrappeMonstre = 0;\n\t\t\t\treturn joueur;\n\t\t\t}\n\t\t}", "public void otpustiVozaca(ActionEvent actionEvent) {\n Driver vozac = model.getTrenutniVozac();\n model.otpustiVozaca(vozac);\n Driver sljedeci = model.getNextDriver(vozac);\n model.setTrenutniVozac(sljedeci);\n this.clearFields();\n }", "private void updateALUTableTomasulo() {\n\t\t// Get a copy of the memory stations\n\t\tALUStation[] temp_alu = alu_rsTomasulo;\n\n\t\t// Update the table with current values for the stations\n\t\tfor (int i = 0; i < temp_alu.length; i++) {\n\t\t\t// generate a meaningfull representation of busy\n\t\t\tString busy_desc = (temp_alu[i].isBusy() ? \"Yes\" : \"No\");\n\n\t\t\tReservationStationModelTomasulo\n\t\t\t\t\t.setValueAt(((temp_alu[i].isReady() && temp_alu[i].isBusy()) ? temp_alu[i].getCycle() : \"0\"), i, 0);\n\n\t\t\tReservationStationModelTomasulo.setValueAt(temp_alu[i].getName(), i, 1);\n\t\t\tReservationStationModelTomasulo.setValueAt(busy_desc, i, 2);\n\t\t\tReservationStationModelTomasulo.setValueAt(((temp_alu[i].isBusy()) ? temp_alu[i].getOperation() : \" \"), i,\n\t\t\t\t\t3);\n\t\t\tReservationStationModelTomasulo.setValueAt(temp_alu[i].getVj(), i, 4);\n\t\t\tReservationStationModelTomasulo.setValueAt(temp_alu[i].getVk(), i, 5);\n\t\t\tReservationStationModelTomasulo.setValueAt(temp_alu[i].getQj(), i, 6);\n\t\t\tReservationStationModelTomasulo.setValueAt(temp_alu[i].getQk(), i, 7);\n\t\t}\n\t}" ]
[ "0.692054", "0.6905883", "0.64707816", "0.62992567", "0.6298006", "0.6290718", "0.6287224", "0.62409437", "0.6222945", "0.6222827", "0.61967766", "0.6174616", "0.6159217", "0.61502314", "0.61463845", "0.61435664", "0.61195254", "0.61088294", "0.60882574", "0.60784304", "0.60741293", "0.60715586", "0.60594815", "0.60483295", "0.6027446", "0.59706116", "0.59704167", "0.59669334", "0.5963219", "0.59500754", "0.5949135", "0.59396625", "0.5930228", "0.5927109", "0.5926258", "0.59193134", "0.59097683", "0.59094286", "0.58938926", "0.588465", "0.58808637", "0.58753735", "0.5872013", "0.5867077", "0.584911", "0.5846814", "0.58408695", "0.5837115", "0.5835272", "0.58189106", "0.5811024", "0.58017135", "0.57957184", "0.5792845", "0.5783961", "0.5782983", "0.576768", "0.5765492", "0.57588375", "0.5757627", "0.57554173", "0.5747254", "0.57470423", "0.5741363", "0.5731398", "0.57123166", "0.5710671", "0.5709028", "0.57080877", "0.57063776", "0.57008934", "0.5680275", "0.56795585", "0.5679356", "0.5678301", "0.5676969", "0.5676588", "0.56764054", "0.56748265", "0.56731164", "0.5664231", "0.5663917", "0.56633854", "0.5662836", "0.5661896", "0.5658948", "0.565611", "0.56505704", "0.5646077", "0.56424904", "0.5641204", "0.56380373", "0.5626927", "0.56235915", "0.56217873", "0.5616602", "0.56117874", "0.56087554", "0.5607823", "0.56041694", "0.5599484" ]
0.0
-1
TODO Autogenerated method stub unos podataka
public static void main(String[] args) { System.out.println("Unesite tezinu(u gramima) prvog pakovanja: "); double gram1=provjera(); System.out.println("Unesite cijenu prvog pakovanja: "); double km1=provjera(); System.out.println("Unesite tezinu(u gramima) drugog pakovanja: "); double gram2=provjera(); System.out.println("Unesite cijenu drugog pakovanja: "); double km2=provjera(); //na kraju ih uporedimo i onaj sa manjom ukupnom cijenom je jeftiniji tj povoljniji if((km1/gram1)<(km2/gram2)){ System.out.println("Prvo pakovanje je povoljnije!!!"); }else{ System.out.println("Drugo pakovanje je povoljnije!!!"); } unos.close(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void perish() {\n \n }", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "@Override\n\tpublic void anular() {\n\n\t}", "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "private RepositorioAtendimentoPublicoHBM() {\r\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\n\tpublic void emprestimo() {\n\n\t}", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "@Override\n\tprotected void getExras() {\n\n\t}", "@Override\n public void inizializza() {\n\n super.inizializza();\n }", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "@Override\n public void memoria() {\n \n }", "public final void mo51373a() {\n }", "@Override\r\n\tpublic void publierEnchere() {\n\t\t\r\n\t}", "@Override\n protected void getExras() {\n }", "private stendhal() {\n\t}", "@Override\n\tprotected void interr() {\n\t}", "@Override\n protected void initialize() {\n\n \n }", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\n\tprotected void logic() {\n\n\t}", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n\tprotected void getData() {\n\t\t\n\t}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "@Override\n public void function()\n {\n }", "@Override\n public void function()\n {\n }", "@Override\r\n\tpublic void stehReagieren() {\r\n\t\t//\r\n\t}", "@Override\n protected void initialize() \n {\n \n }", "public void mo6081a() {\n }", "public void mo38117a() {\n }", "@Override\r\n\t\t\tpublic void buscar() {\n\r\n\t\t\t}", "@Override\n protected void prot() {\n }", "@Override\n\tprotected void initData() {\n\t\t\n\t}", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "@Override\n public void func_104112_b() {\n \n }", "protected void mo6255a() {\n }", "@Override\r\n\tprotected void initVentajas() {\n\r\n\t}", "protected MetadataUGWD() {/* intentionally empty block */}", "public void mo4359a() {\n }", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "@Override\n public void init() {\n\n }", "@Override\r\n\tprotected void InitData() {\n\t\t\r\n\t}", "@Override\n\tprotected void initialize() {\n\n\t}", "@Override\n\tpublic void nghe() {\n\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tpublic void nefesAl() {\n\n\t}", "private void poetries() {\n\n\t}", "@Override\n\t\tpublic void method() {\n\t\t\t\n\t\t}", "Petunia() {\r\n\t\t}", "@Override\r\n\tprotected void initData() {\n\r\n\t}", "@Override\n void init() {\n }", "@Override\n\tprotected void initdata() {\n\n\t}", "@Override\n protected void init() {\n }", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "public contrustor(){\r\n\t}", "@Override\n\tpublic void debite() {\n\t\t\n\t}", "public void mo55254a() {\n }", "@Override\n public void init() {\n }", "@Override\n\tpublic void jugar() {\n\t\t\n\t}", "private static void cajas() {\n\t\t\n\t}", "@Override\r\n\tpublic void voar() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "@Override\n\tpublic void pausaParaComer() {\n\n\t}", "@Override\n\tpublic void one() {\n\t\t\n\t}", "@Override\n\tpublic void buscar() {\n\t\t\n\t}", "private OwBootstrapToIdMapping()\r\n {\r\n\r\n }", "private FlyWithWings(){\n\t\t\n\t}", "@Override\r\n\t\t\tpublic void func02() {\n\t\t\t\t\r\n\t\t\t}", "@Override\n\t\tpublic void rest() {\n\t\t\t\n\t\t}", "public void mo1531a() {\n }", "private RepositorioOrdemServicoHBM() {\n\n\t}" ]
[ "0.6499094", "0.6328467", "0.61594594", "0.6143442", "0.6131912", "0.6094324", "0.604923", "0.60050166", "0.598546", "0.598546", "0.5984658", "0.59602547", "0.5949276", "0.59457", "0.593837", "0.5917045", "0.5865748", "0.5835949", "0.5822599", "0.5816023", "0.5812859", "0.57815593", "0.57762045", "0.57689506", "0.5756694", "0.57381105", "0.57232744", "0.5716016", "0.5716016", "0.56812704", "0.5671772", "0.5671772", "0.5671772", "0.5671772", "0.5671772", "0.5671772", "0.5638283", "0.56287664", "0.5626599", "0.5626599", "0.562619", "0.56007415", "0.55876905", "0.55845517", "0.5571678", "0.5569961", "0.55616474", "0.5560408", "0.5560408", "0.5560408", "0.5560408", "0.5560408", "0.5560408", "0.5560408", "0.5557083", "0.5556118", "0.55442", "0.55385107", "0.5536662", "0.5529846", "0.55261123", "0.55165255", "0.5507168", "0.5501631", "0.5500389", "0.5500389", "0.5500389", "0.5500389", "0.5500389", "0.5500389", "0.549162", "0.5484788", "0.5484788", "0.5481307", "0.5480664", "0.54791355", "0.5473265", "0.5472708", "0.54661304", "0.54655516", "0.5463859", "0.5457163", "0.5457163", "0.54567766", "0.54492676", "0.5448796", "0.5447452", "0.5443463", "0.5436821", "0.54255223", "0.54201305", "0.54170847", "0.5409594", "0.5401677", "0.53981346", "0.53953415", "0.53928393", "0.53877425", "0.53840625", "0.5379098", "0.53737867" ]
0.0
-1
/ Update text views
@Override public void onChanged(Measurement measurement) { updateTextViews(measurement.getTimeStamp(), measurement.isGi(), measurement.getAmount(), measurement.getStress(), measurement.getTired(), measurement.isPhysicallyActivity(), measurement.isAlcoholConsumed(), measurement.isIll(), measurement.isMedication(), measurement.isPeriod(), measurement.getGlucoseStart(), measurement.getGlucose15(), measurement.getGlucose30(), measurement.getGlucose45(), measurement.getGlucose60(), measurement.getGlucose75(), measurement.getGlucose90(), measurement.getGlucose105(), measurement.getGlucose120() ); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void update(String text, TextView view) {\r\n handler.post(new TextUpdater(text, view));\r\n }", "public void updateTextViews() {\n // Set the inputs according to the initial input from the entry.\n //TextView dateTextView = (TextView) findViewById(R.id.date_textview);\n //dateTextView.setText(DateUtils.formatDateTime(getApplicationContext(), mEntry.getStart(), DateUtils.FORMAT_SHOW_DATE));\n\n EditText dateEdit = (EditText) findViewById(R.id.date_text_edit);\n dateEdit.setText(DateUtils.formatDateTime(this, mEntry.getStart(), DateUtils.FORMAT_NUMERIC_DATE | DateUtils.FORMAT_SHOW_DATE | DateUtils.FORMAT_SHOW_YEAR | DateUtils.FORMAT_ABBREV_ALL));\n\n EditText startTimeEdit = (EditText) findViewById(R.id.start_time_text_edit);\n startTimeEdit.setText(DateUtils.formatDateTime(this, mEntry.getStart(), DateUtils.FORMAT_SHOW_TIME));\n\n EditText endTimeEdit = (EditText) findViewById(R.id.end_time_text_edit);\n endTimeEdit.setText(DateUtils.formatDateTime(this, mEntry.getEnd(), DateUtils.FORMAT_SHOW_TIME));\n\n\n TextView descriptionView = (TextView) findViewById(R.id.description);\n descriptionView.setText(mEntry.getDescription());\n\n\n enableSendButtonIfPossible();\n }", "private void updateText() {\n updateDateText();\n\n TextView weightText = findViewById(R.id.tvWeight);\n TextView lowerBPText = findViewById(R.id.tvLowerBP);\n TextView upperBPText = findViewById(R.id.tvUpperBP);\n\n mUser.weight.sortListByDate();\n mUser.bloodPressure.sortListsByDate();\n\n double weight = mUser.weight.getWeightByDate(mDate.getTime());\n int upperBP = mUser.bloodPressure.getUpperBPByDate(mDate.getTime());\n int lowerBP = mUser.bloodPressure.getLowerBPByDate(mDate.getTime());\n\n weightText.setText(String.format(Locale.getDefault(), \"Paino\\n%.1f\", weight));\n lowerBPText.setText(String.format(Locale.getDefault(), \"AlaP\\n%d\", lowerBP));\n upperBPText.setText(String.format(Locale.getDefault(), \"YläP\\n%d\", upperBP));\n\n ((EditText)findViewById(R.id.etWeight)).setText(\"\");\n ((EditText)findViewById(R.id.etLowerBP)).setText(\"\");\n ((EditText)findViewById(R.id.etUpperBP)).setText(\"\");\n }", "public void updateTextView(final String text)\n\t{\n\t\tmHandler.post(new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\tt.setText(text);\n\t\t\t}\n\t\t});\n\t}", "public void updateText(String s){\n TextView articleText = (TextView) findViewById(R.id.article_text);\n articleText.setText(s);\n }", "public void updateViews() {\n textView.setText(contactName);\n\n }", "private void updateText(int nr, View v) {\n if (v.equals(teamAScoreButton)) {\n teamAScoreTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamBScoreButton)) {\n teamBScoreTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamAFaultButton)) {\n teamAFaultTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamBFaultButton)) {\n teamBFaultTextView.setText(String.valueOf(nr));\n }\n }", "private void updateViews() {\n titleTextView.setText(currentVolume.getTitle());\n descTextView.setText(Html.fromHtml(currentVolume.getDesc(), Html.FROM_HTML_MODE_COMPACT));\n authorsTextView.setText(currentVolume.getAuthors());\n\n retrieveImage();\n }", "@Override\r\n\tpublic void updateView(int parseInt, int parseInt2, String string) {\n\r\n\t}", "public void updateText( String text ) {\n\t\tthis.text = text;\n\t}", "void updateView();", "void updateView();", "private void updateText(){\n\t\tif(propertiesObj == null)\n\t\t\treturn;\n\n\t\tif(propertiesObj instanceof QuestionDef)\n\t\t\t((QuestionDef)propertiesObj).setText(txtText.getText());\n\t\telse if(propertiesObj instanceof OptionDef)\n\t\t\t((OptionDef)propertiesObj).setText(txtText.getText());\n\t\telse if(propertiesObj instanceof PageDef)\n\t\t\t((PageDef)propertiesObj).setName(txtText.getText());\n\t\telse if(propertiesObj instanceof FormDef)\n\t\t\t((FormDef)propertiesObj).setName(txtText.getText());\n\n\t\tformChangeListener.onFormItemChanged(propertiesObj);\n\t}", "protected void updateTextChange() {\n \t\t\tfText= fDocumentUndoManager.fTextBuffer.toString();\n \t\t\tfDocumentUndoManager.fTextBuffer.setLength(0);\n \t\t\tfPreservedText= fDocumentUndoManager.fPreservedTextBuffer.toString();\n \t\t\tfDocumentUndoManager.fPreservedTextBuffer.setLength(0);\n \t\t}", "public void updateViews() {\n this.titleTextView.setText(title);\n this.authorTextView.setText(author);\n this.yearTextView.setText(String.valueOf(year));\n this.publisherTextView.setText(publisher);\n if (endsDate != \"\") {\n this.lentToDateTextView.setText(endsDate);\n } else {\n this.lentToDateTextView.setVisibility(View.GONE);\n this.lentToDateLabelTextView.setVisibility(View.GONE);\n }\n }", "public void updateView(String message) {\n output.setText(message);\n \n }", "public void editText(String t, Context ctx){\n\t\t\tChildInteraction cDb = new ChildInteraction(ctx);\t// For Writing to the database\n\t\t\ttext = t;\t\t\t\t\t\t\t\t\t\t\t// set the text\n\t\t\tfor(String key : numbers.keySet())\t\t\t\t\t// for all the numbers\n\t\t\t\tcDb.ChildEditMessage(numbers.get(key), text);\t// edit the text in the db\n\t\t\tcDb.Cleanup();\t\t\t\t\t\t\t\t\t\t// clean up the cursor\n\t\t}", "private void setText(View view, String text) {\n\t\t((TextView) view.findViewById(android.R.id.text1)).setText(text);\n\t}", "void updateText(int c) {\n postInvalidate();\n }", "private void updateInformation(){\n view.getPrompt().setText(getPrompt());\n view.getScore().setText(getScore());\n }", "private void updateCounterView(String text) {\n final String txt = text;\n main.runOnUiThread(new Runnable() {\n @Override\n public void run() {\n if(txt!=null) {\n pointsLeftView.setText(txt);\n } else {\n pointsLeftView.setText(Integer.toString(counter));\n }\n }\n });\n }", "public void setTxtViews(){\n \tupdateTextView(\"Phil Simms\", \"txtPatientName\");\n \tupdateTextView(\"Male\", \"txtPatientGender\");\n \tupdateTextView(\"24\", \"txtPatientAge\");\n \tupdateTextView(\"13\", \"txtPatientRoom\");\n \tupdateTextView(\"Melanoma\", \"txtPatientDiagnosis\");\n \tupdateTextView(\"165\", \"txtPatientWeight\");\n \tupdateTextView(\"10am: Gave tylenol for headache.\", \"txtPatientRecentActions\");\n \tupdateTextView(\"Beach\", \"txtPatientNotes\");\n }", "public void fillText(View view){\n if(running==true){\n\n\n latestOp=false;\n for(int i = 0; i<9; i++)\n if(i==win&&idOfViews[i]==view.getId()) {\n score++;\n sec=sec+3;\n latestOp=true;\n }\n\n //Defining the score\n total++;\n scoret.setText(\" \"+score+\" /\"+total);\n\n //Setting the message about the latest one.\n resultT.setText(\"Missed\");\n if(latestOp==true)\n resultT.setText(\"Correct!\");\n\n\n //Calling a new screen\n newScreen();\n }\n\n\n }", "private void swapContent(){\n Editable content = WordText.getText();\n WordText.setText(TranText.getText());\n TranText.setText(content);\n\n }", "private void updateTextViews(String timeStamp,\n boolean isGi, int amount, String stress, String tired, boolean isPhysicallyActive,\n boolean hasAlcoholConsumed,\n boolean isIll, boolean takesMedication, boolean hasPeriod,\n int mv0, int mv15, int mv30, int mv45, int mv60,\n int mv75, int mv90, int mv105, int mv120) {\n\n /* Update text views */\n\n // Time information\n mBinding.date.setText(\n Converter.convertTimeStampToDate(timeStamp));\n\n mBinding.time\n .setText(Converter.convertTimeStampToTimeStart(timeStamp));\n\n // Advance information\n\n mBinding.amount.setText(Converter.convertInteger(amount));\n\n // If GI measurement disable amount text field\n if (isGi) {\n mBinding.amount.setEnabled(false);\n }\n\n mBinding.stress.setText(stress);\n mBinding.tired.setText(tired);\n mBinding.physicallyActive.setChecked(isPhysicallyActive);\n mBinding.alcoholConsumed.setChecked(hasAlcoholConsumed);\n\n // Events\n mBinding.ill.setChecked(isIll);\n mBinding.medication.setChecked(takesMedication);\n mBinding.period.setChecked(hasPeriod);\n\n // Glucose Values\n mBinding.mv0.setText(Converter.convertIntegerMeasurement(mv0));\n mBinding.mv15.setText(Converter.convertIntegerMeasurement(mv15));\n mBinding.mv30.setText(Converter.convertIntegerMeasurement(mv30));\n mBinding.mv45.setText(Converter.convertIntegerMeasurement(mv45));\n mBinding.mv60.setText(Converter.convertIntegerMeasurement(mv60));\n mBinding.mv75.setText(Converter.convertIntegerMeasurement(mv75));\n mBinding.mv90.setText(Converter.convertIntegerMeasurement(mv90));\n mBinding.mv105.setText(Converter.convertIntegerMeasurement(mv105));\n mBinding.mv120.setText(Converter.convertIntegerMeasurement(mv120));\n }", "public void updateText() throws JUIGLELangException {\n SwingUtilities.invokeLater(new Runnable() {\n\n\n public void run() {\n fireTableStructureChanged();\n }\n });\n\n }", "private void updateView()\r\n\t{\r\n\t\tsupportDatabase.openDataBase();\r\n\t\t\r\n\t\tString language = supportDatabase.getUserSelectedLanguage();\r\n\t\t\r\n\t\tCursor about_info = supportDatabase.getInfoInLanguage(\"Activity_About\", language);\r\n\t\tstartManagingCursor(about_info);\r\n\t\t\r\n\t\tif(about_info.getCount()==1)\r\n\t\t{\r\n\t\t\tabout_info.moveToFirst();\r\n\t\t\taboutHeaderTextView.setText(about_info.getString(about_info.getColumnIndex(\"aboutHeader\")));\r\n\t\t versionTextView.setText(about_info.getString(about_info.getColumnIndex(\"version\")));\r\n\t copyrightTextView.setText(about_info.getString(about_info.getColumnIndex(\"copyright\")));\r\n\t creditsTextView.setText(about_info.getString(about_info.getColumnIndex(\"credits\")));\r\n\t\t\t\r\n\t\t}\r\n//TODO\t\t\t\r\n\t\t\tsupportDatabase.close();\r\n\t\t\r\n\t}", "private void refreshText() {\n mTagsCountText.setText(String.valueOf(tagList.size()));\n\n }", "private void viewChange() {\n currentView = (TextView) findViewById(R.id.currView);\n currentView.setText(counters.get(counterPosition).toString());\n }", "private void updateViews() {\n String twtText = tweetInput.getText().toString();\n int elapsedLength = MAX_CHAR_COUNT - twtText.length();\n if (elapsedLength >= 0 && elapsedLength < MAX_CHAR_COUNT) {\n btnTweet.setEnabled(true);\n charCounter.setTextColor(getResources().getColor(COLOR_GRAY));\n } else {\n btnTweet.setEnabled(false);\n charCounter.setTextColor(getResources().getColor(COLOR_RED));\n }\n\n charCounter.setText(\"\" + elapsedLength);\n }", "public void setView4Text(String text){\n view4Text.set(text);\n }", "private void updateViews(TextView scoreView, TextView timesPlayedView,\n Button numButton1, Button numButton2) {\n //create the text that will be shown. In this case, the text will look like \"Score: 2\".\n String userScoreString = String.format(\"%s %d\",\n getString(R.string.score_text), model.getUserScore());\n\n String userTimesPlayedString = String.format(\"%s %d\",\n getString(R.string.times_played_text), model.getUserTimesPlayed());\n\n //update the textViews\n scoreView.setText(userScoreString);\n timesPlayedView.setText(userTimesPlayedString);\n\n //update the buttons\n numButton1.setText(String.format(\"%d\", model.getLeftnumber()));\n numButton2.setText(String.format(\"%d\", model.getRightNumber()));\n }", "public void updateTaskViews(){\n for (Task task : taskManager.getTasksList()){\n TextView textToChange = (TextView) root.findViewById(task.getIdInView());\n if (textToChange == null){\n submit(task.getName(), task.getIdInView(), task.getTimeForTask(), task.isFinished());\n } else {\n textToChange.setText(task.getName());\n }\n }\n }", "private void updateViews() {\n\t\tList<Task> list = null;\n\t\tDBHelper db = new DBHelper();\n\t\ttry {\n\t\t\tlist = db.getTaskList(this, Task.COLUMN_ID, taskID);\n\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\tLog.e(\"Could not get Single Task\", \"Bam\", e);\n\t\t}\n\n\t\ttask = list.get(0);\n\n\t\tint prioPos = 0;\n\n\t\tfor (int i = 0; i < prioList.size(); i++) {\n\n\t\t\tif (prioList.get(i).getId() == task.getPriority().getId()) {\n\t\t\t\tprioPos = i;\n\t\t\t\tbreak;\n\t\t\t}\n\n\t\t}\n\t\tprioSpinner.setSelection(prioPos);\n\n\t\tint catPos = 0;\n\n\t\tfor (int i = 0; i < categoryList.size(); i++) {\n\n\t\t\tif (categoryList.get(i).getId() == task.getCategory().getId()) {\n\t\t\t\tcatPos = i;\n\t\t\t\tbreak;\n\t\t\t}\n\n\t\t}\n\t\tcategorySpinner.setSelection(catPos);\n\n\t\ttitle.setText(task.getTitle());\n\t\tdescription.setText(task.getDescription());\n\t\tdatePicker.updateDate(task.getAblaufJahr(), task.getAblaufMonat(),\n\t\t\t\ttask.getAblaufTag());\n\t}", "public void onAddText(View view){\n setPage(view);\n int index = deleteView(view);\n addTextField(\"label:\", \"\", index);\n Toast.makeText(this, \"Short Query Added\", Toast.LENGTH_LONG).show();\n }", "public void updateView(String message)\n {\n Log.w(\"MainActivity\",\"In updateview: \" + message);\n\n TextView messageTV = findViewById(R.id.messageTextView);\n\n messageTV.setText(message);\n\n }", "void setText(int offset, int length, String newText)\n\t{\n\t}", "@Override\n\t\t\t\t\t\t\tpublic void run() {\n\t\t\t\t\t\t\t\ttextView.setText(text);\n\t\t\t\t\t\t\t}", "protected TextView setText( final int childViewIndex, final CharSequence text )\n {\n return updater.setText( childViewIndex, text );\n }", "private void updateDisplay() \n\t{\n\t\t// updates the date in the TextView\n if(bir.hasFocus())\n {\n\t\tbir.setText(\n\t\t\t\tnew StringBuilder()\n\t\t\t\t// Month is 0 based so add 1\n\t\t\t\t\n\t\t\t\t.append(mDay).append(\"-\")\n\t\t\t\t.append(mMonth + 1).append(\"-\")\n\t\t\t\t.append(mYear).append(\" \"));\n }else\n {\n\t\taniv.setText(\n\t\t\t\tnew StringBuilder()\n\t\t\t\t// Month is 0 based so add 1\n\t\t\t\t\n\t\t\t\t.append(mDay).append(\"-\")\n\t\t\t\t.append(mMonth + 1).append(\"-\")\n\t\t\t\t.append(mYear).append(\" \"));\n }\n\n\n\t}", "@Override\n public void onClick(View v) {\n Config.context.entry.delete(0);\n Config.context.entry.delete(1);\n // refresh the TextView\n Config.context.textViewMain.setText(Config.context.entry.readFirst(0));\n Config.context.textViewSecond.setText(Config.context.entry.readFirst(1));\n }", "private void updateView() {\r\n if (this.nodes == null || this.nodes.length > 1\r\n || !this.nodes[0].exists()) {\r\n this.titleBorder.setTitle(\"-\");\r\n this.jzvStat.setStat(null);\r\n this.taUpdate.setText(\"\");\r\n this.taChildData.setText(\"\");\r\n this.jbUpdate.setEnabled(false);\r\n this.jbNewChild.setEnabled(false);\r\n this.jbDelete.setEnabled(this.nodes != null);\r\n } else {\r\n this.titleBorder.setTitle(this.nodes[0].getPath());\r\n this.jzvStat.setStat(this.nodes[0].getStat());\r\n byte[] data = this.nodes[0].getData();\r\n this.taUpdate.setText(new String(data == null ? \"null\".getBytes()\r\n : data));\r\n this.taChildData.setText(\"\");\r\n this.jbUpdate.setEnabled( !this.taUpdate.getText().trim().equals(\"\") );\r\n this.jbNewChild.setEnabled( !this.jtfChildName.getText().trim().equals(\"\") );\r\n this.jbDelete.setEnabled(true);\r\n }\r\n this.repaint();\r\n }", "private void refreshInformation () {\n if (textInformation != null) {\n String messageInfo = \"\";\n\n while (!listMessageInfo.isEmpty()) {\n messageInfo = listMessageInfo.getLast() + \"\\n\" + messageInfo;\n listMessageInfo.removeLast();\n }\n\n if (textInformation.getText() != null) {\n textInformation.setText(messageInfo + textInformation.getText());\n } else {\n textInformation.setText(messageInfo);\n }\n }\n }", "private void update_text() {\n\n if(i < text_data.length) {\n i++;\n // text_data.setText(String.valueOf(i)); = avoid the RunTime error\n myHandler.post(myRunnable); // relate this to a Runnable\n } else {\n myTimer.cancel(); // stop the timer\n return;\n }\n }", "private void updateText()\n\t{\n\t\tlong longResult;\t\t//holds the value of result casted to type long\n\t\tif(result % 1 == 0)\n\t\t{\n\t\t\tlongResult = (long)result;\n\t\t\tupdateText += longResult;\n\t\t}\n\t\telse\n\t\t{\n\t\t\tupdateText += result;\n\t\t}\n\t\tentry.setText (\"\");\n\t\tentry.setText (updateText);\n\t\tupdateText = \"\";\n\t\tentry.grabFocus();\n\t}", "private void updateTextBox(){\n\t\tString tmpWord = game.getTempAnswer().toString();\n\t\tString toTextBox = \"\";\n\t\tStringBuilder sb = new StringBuilder(tmpWord);\n\n\t\t//if a letter is blank in the temp answer make it an underscore. Goes for as long as the word length\n\t\tfor (int i = 0; i<tmpWord.length();i++){\n\t\t\tif(sb.charAt(i) == ' ')\n\t\t\t\tsb.setCharAt(i, '_');\n\t\t}\n\t\ttoTextBox = sb.toString();\n\t\ttextField.setText(toTextBox);\n\t\tlblWord.setText(toTextBox);\n\t}", "private void updateTransferText() {\n downloadsLine.setValue((Integer) downloadsCountVM.getValue());\n uploadsLine.setValue((Integer) uploadsCountVM.getValue());\n }", "@Override\n\t\t\tpublic void setTextView(String str) {\n\t\t\t\t\n\t\t\t}", "public void update() {\n\t\tthis.editorView.update();\n\t}", "private void updateView() {\n model.inlezenHighscore();\n for (int i = 0; i < 10; i++) {\n view.getNaamLabels(i).setText(model.getNaam(i));\n view.getScoreLabels(i).setText(model.getScores(i));\n }\n }", "private void updateOutputText() {\r\n UiApplication.getUiApplication().invokeLater(new Runnable() {\r\n public void run() {\r\n _outputText.setText(_output);\r\n }\r\n });\r\n }", "public void setText(String text) {\n\t\tthis.text = text;\n\t\tupdateView();\n\t}", "private void setTextViews() {\n TextView textToggleFilters = (TextView) findViewById(R.id.text_totalExpenditure);\n textToggleFilters.setPaintFlags(textToggleFilters.getPaintFlags() | Paint.FAKE_BOLD_TEXT_FLAG);\n }", "private void updateCountTV()\n {\n TextView countTextview = (TextView) findViewById(R.id.countTV);\n countTextview.setText(\"Counting Jelly Beans gives me \" + countJB);\n }", "public void updateAnswer(String text) {\n\t\tclearAnswer();\n\t\t\n\t\t// Add new label with the string\n\t\tlbl.setText(text);\n\t\tvPanel.add(lbl);\n\n\t\treturn;\n\t}", "private void setTextWithContent(int index, JSONObject jsonObject) {\n try {\n TextView textView = (TextView) viewAll\n .findViewById(dayTextView[index]);\n String day = jsonObject.getString(\"date\");\n String week = Util.getWeekByDayString(day);\n String txt_d = jsonObject.getString(\"txt_d\");\n String txt_n = jsonObject.getString(\"txt_n\");\n String afasf = txt_d;\n SpannableString spannableString = new SpannableString(week + \"\\n\"\n + afasf);\n spannableString.setSpan(new AbsoluteSizeSpan(12, true),\n week.length(), week.length() + afasf.length() + 1,\n SpannableString.SPAN_EXCLUSIVE_EXCLUSIVE);\n textView.setText(spannableString);\n\n TextView textViewS = (TextView) viewAll\n .findViewById(dayTextViewN[index]);\n SpannableString spannableString2 = new SpannableString(txt_n);\n spannableString2.setSpan(new AbsoluteSizeSpan(12, true), 0,\n txt_n.length(), SpannableString.SPAN_EXCLUSIVE_EXCLUSIVE);\n textViewS.setText(spannableString2);\n\n ImageView IMAGEAe = (ImageView) viewAll\n .findViewById(iconView[index]);\n Util.setQingYinImage(IMAGEAe, afasf, true);\n\n ImageView IMAGEAdddde = (ImageView) viewAll\n .findViewById(iconViewN[index]);\n Util.setQingYinImage(IMAGEAdddde, txt_n, false);\n\n TextView tempTextVieadAsdw = (TextView) viewAll\n .findViewById(tempTextView[index]);\n String adasf = jsonObject.getString(\"min_tmp\") + \"/\"\n + jsonObject.getString(\"max_tmp\");\n Util.setTempreTure(adasf, tempTextVieadAsdw);\n\n } catch (Exception e) {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }\n }", "protected void updateVolumeTextView(String text) {\n mVolTextView.setText(text);\n }", "private void updateText(final String info, final String caller) {\n\t\trunOnUiThread(new Runnable() {\n\t\t\tpublic void run() {\n\n\t\t\t\tinfoText.setText(info);\n\t\t\t\tcallerText.setText(caller);\n\t\t\t}\n\t\t});\n\t}", "void setText(String text);", "private void setText(Text text) {\n \t\tthis.text = text;\n \t}", "public void updateUi() {\n updateTextView(R.id.blindword, gameInstance.getBlindWord(), EditMode.ADDSPACING);\n updateTextView(R.id.guessedletters, gameInstance.getGuessedSoFar(), EditMode.ADDSPACING);\n\n int livesTotal = settings.getInt(\"lives\", 7);\n int livesLeft = gameInstance.getLives();\n StringBuilder healthbar = new StringBuilder();\n for(int i=0;i<livesLeft;i++) {\n healthbar.append('\\u2764'); //black heart\n }\n\n for(int i=0;i<(livesTotal - livesLeft);i++) {\n healthbar.append('\\u2661'); //white heart\n }\n\n updateTextView(R.id.healthbar, healthbar.toString(), EditMode.NONE);\n\n gameOverListener();\n\n }", "@Override\n \t\t\tpublic void afterTextChanged(Editable s) {\n \t\t\t\tNoteEditView.this.mNoteItemModel.setContent(s.toString());\n \t\t\t}", "@Override\n public void update() {\n CommandNodeGameState gs = (CommandNodeGameState) state;\n String acc = String.valueOf(gs.getAcc());\n accView.setText(acc);\n String bak = String.valueOf(gs.getBak());\n bakView.setText(bak);\n String last = String.valueOf(gs.getLast());\n lastView.setText(last);\n String mode = String.valueOf(gs.getMode());\n modeView.setText(mode);\n String idle = String.valueOf(0);\n idleView.setText(idle);\n\n StringBuilder builder = new StringBuilder();\n for (int i = 0; i < gs.lineCount(); i++) {\n builder.append(gs.getLine(i).toString());\n builder.append(\"\\n\");\n }\n textArea.setText(builder.toString());\n\n if (state.isActive()) {\n highlightedLine = gs.getSelectedLine();\n } else {\n highlightedLine = null;\n }\n invalidate();\n }", "public void setText(String text);", "private void flushImpl() {\r\n String s = null;\r\n\r\n // grab data from the buffer\r\n synchronized (this) {\r\n if (buffer.length() > 0) {\r\n s = buffer.toString();\r\n buffer.setLength(0);\r\n }\r\n }\r\n\r\n // don't do anything if buffer was empty\r\n if (s != null) {\r\n try {\r\n boolean scroll = false;\r\n Document d = textViewer.getDocument();\r\n int docLen = d.getLength();\r\n if (docLen > 0) {\r\n scroll = (textViewer.getCaretPosition() >= (docLen-1));\r\n }\r\n\r\n // Insert new text:\r\n d.insertString(d.getLength(), s, attributes);\r\n\r\n // Is number of lines limited?\r\n if (isSizeLimited() && docLen > getMaxSize()) {\r\n Element root = d.getDefaultRootElement();\r\n int i = root.getElementIndex(docLen - getMaxSize());\r\n if (i >= 0) {\r\n Element e = root.getElement(i);\r\n int offset = e.getEndOffset();\r\n d.remove(0,Math.min(offset,docLen));\r\n }\r\n }\r\n\r\n // Scroll view to the end only if cursor was at the end:\r\n if (scroll) {\r\n textViewer.setCaretPosition(d.getLength());\r\n }\r\n\r\n // Update summary view:\r\n if (summaryView != null && d.getLength() > 0) {\r\n Element root = d.getDefaultRootElement();\r\n int n = root.getElementCount();\r\n if (n > 0) {\r\n Element last = root.getElement(n-1);\r\n int start = last.getStartOffset();\r\n int end = last.getEndOffset();\r\n if ((end-start) <= 1 && n > 1) {\r\n last = root.getElement(n-2);\r\n start = last.getStartOffset();\r\n end = last.getEndOffset();\r\n }\r\n\r\n AttributeSet a = last.getAttributes();\r\n Object fg = a.getAttribute(StyleConstants.Foreground);\r\n Object bg = a.getAttribute(StyleConstants.Background);\r\n if (!(fg instanceof Color)) {\r\n fg = LookFactory.getCodeColorSet().foregroundColor;\r\n }\r\n if (!(bg instanceof Color)) {\r\n bg = LookFactory.getCodeColorSet().backgroundColor;\r\n }\r\n summaryView.setForeground((Color)fg);\r\n summaryView.setBackground((Color)bg);\r\n\r\n String text = d.getText(start,end-start);\r\n if (text.length() > 0) {\r\n summaryView.setText(text);\r\n } else {\r\n summaryView.clear();\r\n }\r\n }\r\n }\r\n\r\n // Write the file:\r\n if (fileWriter != null) {\r\n char lastChar = lastFileChar;\r\n int len = s.length();\r\n for (int i=0; i<len; i++) {\r\n char c = s.charAt(i);\r\n if (c == '\\n') {\r\n if (lastFileChar == '\\r') {\r\n fileWriter.write(c);\r\n } else {\r\n // Use platform-specific end of line seq\r\n fileWriter.println();\r\n }\r\n } else {\r\n fileWriter.write(c);\r\n }\r\n lastChar = c;\r\n }\r\n\r\n lastFileChar = lastChar;\r\n fileWriter.flush();\r\n }\r\n\r\n } catch(Exception ex) {\r\n ex.printStackTrace();\r\n }\r\n }\r\n }", "protected void updateViewerInput() {\n \t\tIStructuredSelection selection= (IStructuredSelection) fTableViewer.getSelection();\n \n \t\tif (selection.size() == 1) {\n \t\t\tTemplatePersistenceData data= (TemplatePersistenceData) selection.getFirstElement();\n \t\t\tTemplate template= data.getTemplate();\n \t\t\tfPatternViewer.getDocument().set(template.getPattern());\n \t\t} else {\n \t\t\tfPatternViewer.getDocument().set(\"\"); //$NON-NLS-1$\n \t\t}\n \t}", "private void viewExtractedData() {\n txtViewer.setText(extractedData);\n }", "public void update() {\r\n if (parseStyle == ParseStyle.CHARACTER) {\r\n wrapText();\r\n int begin = getPosition();\r\n int end = getPosition() + 1;\r\n setCurrentItem(new TextItem(begin, end, getText().substring(begin,\r\n end)));\r\n setPosition(end);\r\n } else if (parseStyle == ParseStyle.WORD) {\r\n if (matcher == null) {\r\n return;\r\n }\r\n wrapText();\r\n boolean matchFound = findNextToken();\r\n if (matchFound) {\r\n selectCurrentToken();\r\n } else {\r\n // No match found. Go back to the beginning of the text area\r\n // and select the first token found\r\n setPosition(0);\r\n updateMatcher();\r\n // Having wrapped to the beginning select the next token, if\r\n // there is one.\r\n if (findNextToken()) {\r\n selectCurrentToken();\r\n }\r\n }\r\n }\r\n\r\n }", "public void setText( String text );", "private void updateNameView() {\n String insertedText = getName();\n\n if (seekBar.getProgress() == 0) {\n insertedText = \"\";\n }\n\n String text = String.format(res.getString(R.string.str_tv_firstName_value), insertedText);\n\n nameView.setText(text);\n }", "public static void updateTextArea(String text) {\n\t\tchat.append(text);\n\t\tchat.setCaretPosition(chat.getDocument().getLength());\n\t}", "public void updateView(ClientView view);", "void setText (String text);", "public void updateArticleView(ServerObj serverObj){\n View v = getView();\n// String[] data = Ipsum.Articles;\n// article.setText(data[position]);\n// currentPosition = position;\n currentServerObj=serverObj;\n LinearLayout containerOfContents= (LinearLayout) v.findViewById(R.id.container_of_contents);\n containerOfContents.removeAllViews();\n ContentsViewBuilder contentsViewBuilder=new ContentsViewBuilder(activity);\n Log.d(\"myPavilion\",\"serverObj\"+serverObj.getJson());\n View contentsView=contentsViewBuilder.getView(serverObj.getContentsObj());\n containerOfContents.addView(contentsView);\n\n }", "protected void redoTextChange() {\n \t\t\ttry {\n \t\t\t\tif (fDocumentUndoManager.fDocument instanceof IDocumentExtension4)\n \t\t\t\t\t((IDocumentExtension4) fDocumentUndoManager.fDocument).replace(fStart, fEnd - fStart, fText, fRedoModificationStamp);\n \t\t\t\telse\n \t\t\t\t\tfDocumentUndoManager.fDocument.replace(fStart, fEnd - fStart, fText);\n \t\t\t} catch (BadLocationException x) {\n \t\t\t}\n \t\t}", "private void SetViewAndAutoCompleteText(int viewID)\n\t{\n\t\t// Auto complete words\n // !put, !get, !capture, !launch, !autotest are special commands\n\t\tfinal String [] COMMAND_LIST = new String [] { \n\t\t\t\t\"!put a.txt\", \"!get c:/test.txt\", \"!capture 1.jpg\", \"!launch\", \n\t\t\t\t\"dir\", \"cd \", \"cd ..\", \"c:\", \"tasklist\" };\n\t\tfinal String [] KEY_LIST = new String [] { \n\t\t\t\t\"!autotest\", \"!pintest\", \"!stoptest\", \"[KEY_\", \"[KEY_LGUI]\", \"[KEY_LGUI][KEY_R]\", \"[KEY_LGUI][KEY_L]\", \"[KEY_LALT]\", \"[KEY_LALT][KEY_F4]\", \"[KEY_LCONTROL]\", \"[KEY_LCONTROL][KEY_S]\", \"[KEY_UP]\",\n\t\t\t\t\"[KEY_LSHIFT]\",\t\"[KEY_ENTER]\", \"[KEY_BACKSPACE]\", \"cmd.exe\", \"d:/testagent\" };\n\t\t\n\t\t// Set view pointer\n\t\tView view;\n\t\tAutoCompleteTextView autoText;\n\t\tArrayAdapter<String> adapter;\n\t\t\n\t\t// Set view pointer\n\t\tif (viewID == VIEW_ID_COMMAND)\n\t\t{\n\t\t\tview = mTabHost.getTabContentView().findViewById(R.id.commandView);\n\t\t\tmCommandView = (TextView)view.findViewById(R.id.dataview);\n\t\t\tmCommandScrollView = (ScrollView)view.findViewById(R.id.scrollview);\n\t\t\tmCommandInputView = (AutoCompleteTextView) view.findViewById(R.id.commandInput);\n\t\t\tautoText = mCommandInputView;\n\t\t\tadapter = new ArrayAdapter(getApplicationContext(), \n\t\t\t\t\tandroid.R.layout.simple_dropdown_item_1line, COMMAND_LIST);\n\t\t}\n\t\telse\n\t\t{\n\t\t\tview = mTabHost.getTabContentView().findViewById(R.id.keyView);\n\t\t\tmKeyView = (TextView)view.findViewById(R.id.dataview);\n\t\t\tmKeyScrollView = (ScrollView)view.findViewById(R.id.scrollview);\n\t\t\tmKeyInputView = (AutoCompleteTextView) view.findViewById(R.id.keyInput);\n\t\t\tautoText = mKeyInputView;\n\t\t\tadapter = new ArrayAdapter(getApplicationContext(), \n\t\t\t\t\tandroid.R.layout.simple_dropdown_item_1line, KEY_LIST);\t\t\t\n\t\t}\t\t\n\t\t\n\t\t// Set options for autocomplete\n\t\tautoText.setTag(viewID);\n\t\tautoText.setAdapter(adapter);\n\t\tautoText.setThreshold(1);\n\t\t\n\t\t// Process enter key\n\t\tautoText.setOnKeyListener(new OnKeyListener()\n\t\t{\n\t\t\t@Override\n\t\t\tpublic boolean onKey(View arg0, int arg1, KeyEvent arg2) \n\t\t\t{\t\t\t\t\n\t\t\t\tif ((arg0 != null) && (arg2 != null) && \n\t\t\t\t\t(arg2.getAction() == KeyEvent.ACTION_DOWN) &&\n\t\t\t\t\t(arg2.getKeyCode() == KeyEvent.KEYCODE_ENTER))\n\t\t\t\t{\n\t\t\t\t\tAutoCompleteTextView view = (AutoCompleteTextView) arg0;\n\t\t\t\t\tString data;\n\t\t\t\t\tint viewID;\n\t\t\t\t\t\n\t\t\t\t\tdata = view.getText().toString();\n view.setText(\"\");\n viewID = (Integer) view.getTag();\n if (data.equals(\"\") == true)\n {\n if (viewID == VIEW_ID_KEY)\n {\n data = \"[KEY_ENTER]\";\n }\n else\n {\n return true;\n }\n }\n\n SendCommandOrKeys(viewID, data);\n\n\t\t\t\t\treturn true;\n\t\t\t\t}\n\t\t\t\treturn false;\n\t\t\t}\n\t\t});\t\t\n\t}", "private void updateDisplayText(double change) { updateDisplayText(change, null); }", "public void updateText() {\n\n dateText = dateFormat.format(c.getTime());\n timeText = timeFormat.format(c.getTime());\n dateEt.setText(dateText + \" \"+ timeText);\n}", "private void updateQuestion(){\n int question = mQuestionBank[mCurrentIndex].getmQuestion();\n mQuestionTextView.setText(question);\n }", "private void setText(final String text) {\n runOnUiThread(new Runnable() {\n @Override\n public void run() {\n TextView textView = findViewById(R.id.loading_text);\n if (textView != null) {\n textView.setText(textView.getText() + \"\\n\" + formatDate(System.currentTimeMillis()) + \": \" + text);\n }\n }\n });\n }", "private void setView(LockedDocument doc) {\n\t\ttext1.setText(doc.getTitle());\n\t\ttext2.setText(doc.getContents());\n\t\ttext1.setFocusableInTouchMode(true);\n\t\ttext1.setEnabled(true);\n\t\ttext2.setFocusableInTouchMode(true);\n\t\ttext2.setEnabled(true);\n\t\tlock.setEnabled(false);\n\t\trefresh.setEnabled(false);\n\t\tsave.setEnabled(true);\n\t}", "@Override\r\n\t\tpublic void updateUI() {\n\t\t\tif(deparments != null){\r\n\r\n\t\t\t\ttv.setText(deparments.toString());\r\n\t\t\t}else{\r\n\t\t\t\tSystem.out.println(\"deparments \"+deparments.toString());\r\n\t\t\t}\r\n\t\t}", "@Test\n public void ensureTextChangesWork(){\n onView(withId(R.id.placeEditText)).perform(typeText(\"London\"));\n\n // Check that the language text was changed.\n onView(withId(R.id.languageEditText)).perform(typeText(\"It\"));\n\n // Check that the language text was changed.\n onView(withId(R.id.maxrowsEditText)).perform(typeText(\"3\"));\n\n // check button click\n onView(withId(R.id.button)).perform(click());\n\n // check returned list view\n onView(withId(R.id.listViewResult)).check(matches(isDisplayed()));\n }", "public void onClick(View view){ // that executes the following code.\n // Take the text input to the EditText field...\n String changeText = editV.getText().toString();\n // and set the TextView to that input.\n textV.setText(changeText);\n }", "public void updateSettings(String name)\n {\n //SET TEXTVIEWS\n /*\n TextView nameOfView1 = (TextView) findViewById(R.id.nameOfView);\n\t\tTextView nameOfView2 = (TextView) findViewById(R.id.nameOfView);\n\t\tnameOfView1.setText(name);\n\t\tif (boolean value true)\n\t\t\tnameOfView2.setText(\"\");\n\t\telse\n\t\t\tnameOfView2.setText(\"\");\n */\n }", "private void setStatTextViews() {\n TextView numLives = findViewById(R.id.lives);\n numLives.setText(String.valueOf(player.getLives()));\n\n TextView multiplier = findViewById(R.id.currMultiply);\n multiplier.setText(String.valueOf(player.getMultiplier()));\n\n TextView totalPoint = findViewById(R.id.currScore);\n totalPoint.setText(String.valueOf(player.getPoints()));\n }", "public abstract void setText(String txt);", "void setEditFrameText(Motion m);", "private void updateSourceView() {\n StringWriter sw = new StringWriter(200);\n try {\n new BibEntryWriter(new LatexFieldFormatter(Globals.prefs.getLatexFieldFormatterPreferences()),\n false).write(entry, sw, frame.getCurrentBasePanel().getBibDatabaseContext().getMode());\n sourcePreview.setText(sw.getBuffer().toString());\n } catch (IOException ex) {\n LOGGER.error(\"Error in entry\" + \": \" + ex.getMessage(), ex);\n }\n\n fieldList.clearSelection();\n }", "public void setText(String text){\n this.roomText = text;\n this.hasText = true;\n }", "public void resetText(View view) {\n display();\n }", "public void updateText()\r\n\t{\r\n\t\tdouble smallest = Math.min(menu.getController().getWidth(), menu.getController().getHeight());\r\n\t\tdouble equivalent12 = smallest/55;//Equivalent of 12 point font on base dimensions\r\n\t\t\r\n\t\ttextRenderer = new TextRenderer(new Font(fontName, Font.PLAIN, (int)(equivalent12*size)), true, true);\r\n\t}", "private void updateTexts( DocumentEvent e ) {\n Document doc = e.getDocument();\n if (doc == projectNameTextField.getDocument() || doc == projectLocationTextField.getDocument()) {\n String projectName = projectNameTextField.getText();\n \n if (doc == projectLocationTextField.getDocument()) {\n if (projectName.equals(generatedProjectName)) {\n File f = new File(projectLocationTextField.getText().trim());\n generatedProjectNameIndex = getValidProjectNameIndex(nameFormatter, generatedProjectNameIndex, f);\n } else {\n generatedProjectNameIndex = 0;\n }\n generatedProjectName = generatedProjectNameIndex > 0 ? getProjectName(nameFormatter, generatedProjectNameIndex) : null;\n if(generatedProjectNameIndex > 0) {\n projectName = generatedProjectName;\n projectNameTextField.setText(generatedProjectName);\n projectNameTextField.selectAll();\n }\n }\n \n String projectFolder = projectLocationTextField.getText();\n String projFolderPath = FileUtil.normalizeFile(new File(projectFolder)).getAbsolutePath();\n if (projFolderPath.endsWith(File.separator)) {\n createdFolderTextField.setText(projFolderPath + projectName);\n } else {\n createdFolderTextField.setText(projFolderPath + File.separator + projectName);\n }\n }\n wizard.fireChangeEvent();\n }", "private void setTextboxesToContainedData()\n {\n updateWeightTextFieldToStored(\"failure loading default\");\n updateSpriteTextFieldToStored(\"failure loading default\");\n }", "protected TextView textView( final int childViewIndex )\n {\n return updater.textView( childViewIndex );\n }", "protected void updateDisplays() {\n \trecordDisplay.setText(formatField());\n \tif(updated) {\n \t\trecordDisplay.setFont(regularFont);\n \t} else {\n \t\trecordDisplay.setFont(italicFont);\n \t}\n }", "public void setText(String text) {\n if (text.equals(_text))\n return;\n\n _text = text;\n resetLayout();\n //enableCache(text != null && text.length() != 0);\n update();\n }", "void updateViewFromModel();", "public static ViewAction setTextInTextView(final String value){\n return new ViewAction() {\n @SuppressWarnings(\"unchecked\")\n @Override\n public Matcher<View> getConstraints() {\n return allOf(isDisplayed(), isAssignableFrom(TextView.class));\n }\n\n @Override\n public void perform(UiController uiController, View view) {\n ((TextView) view).setText(value);\n }\n\n @Override\n public String getDescription() {\n return \"replace text\";\n }\n };\n }", "public void updateViews() {\n updateViews(null);\n }", "@Override\n public void updateView(Message msg)\n {\n \n }" ]
[ "0.7565304", "0.7417287", "0.71122855", "0.7020788", "0.696962", "0.6892523", "0.6884191", "0.68468374", "0.6771364", "0.67454034", "0.6715992", "0.6715992", "0.6699263", "0.66988355", "0.6690203", "0.6607724", "0.6601401", "0.6574937", "0.6530213", "0.6497273", "0.64915", "0.64875835", "0.646996", "0.646921", "0.64506316", "0.64253753", "0.6402863", "0.6402603", "0.6375913", "0.63705534", "0.6353231", "0.6307101", "0.6294389", "0.6279669", "0.6249682", "0.6243191", "0.62335044", "0.6231036", "0.6225788", "0.62012166", "0.618792", "0.6179522", "0.6178716", "0.6172913", "0.6172102", "0.61691695", "0.61598223", "0.6153447", "0.61527926", "0.6142525", "0.6125306", "0.61165345", "0.6111534", "0.61115235", "0.6110885", "0.6096748", "0.6093645", "0.60845584", "0.60812485", "0.60763085", "0.6074045", "0.60685617", "0.60626084", "0.6053166", "0.60485303", "0.604425", "0.60351956", "0.6025328", "0.6022558", "0.6018472", "0.6011984", "0.6011056", "0.60069454", "0.60008913", "0.59989166", "0.5993083", "0.5990352", "0.59878004", "0.5977623", "0.59771186", "0.5975084", "0.597429", "0.596772", "0.59654754", "0.59634846", "0.5962644", "0.5960449", "0.5960129", "0.59569514", "0.5943113", "0.5941833", "0.5926919", "0.5913368", "0.5912923", "0.5912134", "0.5911151", "0.5909989", "0.590562", "0.5903911", "0.59038913", "0.5902621" ]
0.0
-1
Build a string of a date by using the calender class with the pattern dd.mm.yyyy Example: 11.10.2019
@Override public void onDateSet(DatePicker view, int year, int month, int dayOfMonth) { Calendar calendar = Calendar.getInstance(); calendar.set(year, month, dayOfMonth, 0, 0, 0); Date date = calendar.getTime(); SimpleDateFormat sdf = new SimpleDateFormat("dd.MM.yyyy", Locale.getDefault()); mBinding.date.setText(sdf.format(date)); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private static String getDateStr() {\n\t\tDate date = Calendar.getInstance().getTime();\n\t\tDateFormat dateFormat = new SimpleDateFormat(\"MMddyyy\");\n\t\tString dateStr = dateFormat.format(date);\n\t\treturn dateStr;\n\t}", "private String dateToString(Date datum)\r\n\t{\n\t\tSimpleDateFormat df = new SimpleDateFormat(\"dd.MM.yyyy\");\r\n\t\tString dat = df.format(datum);\r\n\t\treturn dat;\r\n\t}", "public String convertDateToString(){\n\t\tString aDate = \"\";\n\t\taDate += Integer.toString(day);\n\t\taDate += \"/\";\n\t\taDate += Integer.toString(month);\n\t\taDate += \"/\";\n\t\taDate += Integer.toString(year);\n\t\treturn aDate;\n\t}", "public static String getDate() {\n\t\tDate date = new Date();\n\t\tSimpleDateFormat formatter = new SimpleDateFormat(\"ddMMYYYY\");\n\t\tString strDate = formatter.format(date);\n\t\treturn strDate;\n\t}", "public static String getDateString(Calendar cal) {\n\t\tString month = Integer.toString(cal.get(Calendar.MONTH)+1);\n\t\tString day = Integer.toString(cal.get(Calendar.DAY_OF_MONTH));\n\t\tString year = Integer.toString(cal.get(Calendar.YEAR));\n\t\treturn month + \"/\" + day + \"/\" + year;\n\t}", "public String getDateString() {\n int year = date.get(Calendar.YEAR);\n int month = date.get(Calendar.MONTH); // month is stored from 0-11 so adjust +1 for final display\n int day_of_month = date.get(Calendar.DAY_OF_MONTH);\n return String.valueOf(month + 1) + '/' + String.valueOf(day_of_month) + '/' + year;\n }", "public String getStringDate(){\n String finalDate = \"\";\n Locale usersLocale = Locale.getDefault();\n DateFormatSymbols dfs = new DateFormatSymbols(usersLocale);\n String weekdays[] = dfs.getWeekdays();\n int day = date.get(Calendar.DAY_OF_WEEK);\n String nameOfDay = weekdays[day];\n\n finalDate += nameOfDay + \" \" + date.get(Calendar.DAY_OF_MONTH) + \", \";\n\n String months[] = dfs.getMonths();\n int month = date.get(Calendar.MONTH);\n String nameOfMonth = months[month];\n\n finalDate += nameOfMonth + \", \" + date.get(Calendar.YEAR);\n\n return finalDate;\n }", "private String makeDateString(int day, int month, int year) {\n String str_month = \"\" + month;\n String str_day = \"\" + day;\n if (month < 10) {\n str_month = \"0\" + month;\n }\n if (day < 10) {\n str_day = \"0\" + day;\n }\n return year + \"-\" + str_month + \"-\" + str_day;\n }", "public String getDate(){\n String d=\"\";\n String m=\"\";\n if(day<10){\n d=0+(String.valueOf(day));\n }\n else{\n d=String.valueOf(day);\n }\n\n if(month<10){\n m=0+(String.valueOf(month));\n }\n else{\n m=String.valueOf(month);\n }\n //returning day/month/year\n return (d+\"/\"+m+\"/\"+String.valueOf(year));\n }", "private String createDate(){\n SimpleDateFormat date = new SimpleDateFormat(\"EEE, MMM d, yyyy\");\n String stringDate = date.format(new Date()); \n return stringDate;\n }", "private String getDateTime() {\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"dd.MM.yyyy\", Locale.GERMANY);\n Date date = new Date();\n return dateFormat.format(date);\n }", "public String toStringDateOfBirth() {\n\t\tDateTimeFormatter format = DateTimeFormatter.ofPattern(\"dd/MM/yyyy\");\n\t\treturn dateofbirth.format(format);\n\t}", "public String getDateString(){\n return Utilities.dateToString(date);\n }", "@Override\n public String toString() {\n return date.format(DateTimeFormatter.ofPattern(\"dd.MM.yyyy\")) + \" - \" + note;\n }", "private static String convertToDDMMYYYY(Date date) {\n\t\tString returnStr = \"\";\n\t\ttry {\n\t\tDateFormat format1 = new SimpleDateFormat(\"dd/MM/yyyy\");\n\t\treturnStr = format1.format(date);\n\t\t\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn returnStr;\n\t}", "public static String dateStr(String input ){\n String mm = input.substring(0,2);\n String dd = input.substring(3,5);\n String yyyy = input.substring(6,10);\n return dd + \" - \" + mm + \" - \" + yyyy;\n }", "java.lang.String getDate();", "public String toString() { //toString method\n String startDateString2= \"\"; //Initialize\n try{\n Date date1 = new SimpleDateFormat(\"yyyyMMdd\").parse(full_Date);\n DateFormat df2 = new SimpleDateFormat(\"MMM dd, yyyy\");\n startDateString2 = df2.format(date1);\n \n return startDateString2;\n }catch(ParseException e){\n e.printStackTrace();\n }\n return startDateString2;\n \n}", "public static String generateDate()\r\n\t{\r\n\t\tDate d = new Date();\r\n\t\tSimpleDateFormat datef = new SimpleDateFormat(\"YYYY_MM_dd_ss\");\r\n\t\treturn datef.format(d);\r\n\r\n\r\n\t}", "public static String dateToString(Date date){\n\t\tSimpleDateFormat formatter = new SimpleDateFormat(\"MMddyy\");\n\t\treturn formatter.format(date);\n\t}", "public static String generateCurrentDayString() {\n\t\tSimpleDateFormat dateFormat = new SimpleDateFormat(\"yyyy-MM-dd\");\n\t\treturn dateFormat.format(new Date());\n\t}", "private String toDate(Date appDate) throws ParseException {\n\t\tCalendar cal = Calendar.getInstance();\n\t\tcal.setTime(appDate);\n\t\tString formatedDate = cal.get(Calendar.DATE) + \"/\" + (cal.get(Calendar.MONTH) + 1) + \"/\" + cal.get(Calendar.YEAR);\n\t\tSystem.out.println(\"formatedDate : \" + formatedDate); \n\t\treturn formatedDate;\n\t}", "java.lang.String getToDate();", "public String dateToString() {\n\t\treturn new String(year + \"/\"\n\t\t\t\t+ month + \"/\"\n\t\t\t\t+ day);\n }", "public static String dateDisplay(Calendar cal) {\n\t\tLONGDAYS[] arrayOfDays = LONGDAYS.values();\n\t\tString toReturn = cal.get(Calendar.MONTH)+1 + \"/\" + cal.get(Calendar.DAY_OF_MONTH);\n\t\ttoReturn = arrayOfDays[cal.get(Calendar.DAY_OF_WEEK)-1] + \" \" + toReturn;\n\t\treturn toReturn;\n\t}", "public static String formatDate(Date d) {\n\t\tint month = d.getMonth() + 1;\n\t\tint dayOfMonth = d.getDate();\n\t\tint year = d.getYear() + 1900;\n\t\tString y = \"\" + year;\n\t\tString m = \"\" + month;\n\t\tString dom = \"\" + dayOfMonth;\n\t\tif (month < 10) {\n\t\t\tm = \"0\" + m;\n\t\t}\n\t\tif (dayOfMonth < 10) {\n\t\t\tdom = \"0\" + dom;\n\t\t}\n\t\treturn m + \"/\" + dom + \"/\" + y.substring(2);\n\t}", "private String getDate(int year, int month, int day) {\n return new StringBuilder().append(month).append(\"/\")\n .append(day).append(\"/\").append(year).toString();\n }", "private static String generateDateString(int year, int month, int dayOfMonth){\n //Add one to month b/c Android is zero-based while SimpleDateFormatter is not\n month++;\n String yearString = String.format(Locale.getDefault(), \"%04d\", year);\n String monthString = String.format(Locale.getDefault(), \"%02d\", month);\n String dayOfMonthString = String.format(Locale.getDefault(), \"%02d\", dayOfMonth);\n\n String result = yearString + \".\" + monthString + \".\" + dayOfMonthString;\n return result;\n }", "protected String formatDateToString(Date date) {\n\t\tSimpleDateFormat format = new SimpleDateFormat(\"yyyy.MM.dd HH:mm:ss\");\n\t\tString formatted = format.format(date);\n\t\treturn formatted;\n\t}", "private String formatDate(final Date date) {\r\n\t\tfinal Calendar calendar = Calendar.getInstance();\r\n\t\tcalendar.setTime(date);\r\n\r\n\t\tfinal String dayOfMonth = formatDayOfMonth(calendar);\r\n\t\tfinal String month = formatMonth(calendar);\r\n\t\tfinal String year = String.valueOf(calendar.get(Calendar.YEAR));\r\n\r\n\t\treturn String.format(\"%s/%s/%s\", year, month, dayOfMonth);\r\n\t}", "public static String getDateString(){\n\t\t\tCalendar now = Calendar.getInstance();\n\t\t\tSimpleDateFormat sdf = new SimpleDateFormat(\"yyyy-MM-dd__HH-mm-ss\");\n\t\t\treturn sdf.format(now.getTime());\n\t }", "private String getDateString(Calendar cal) {\n Calendar current = Calendar.getInstance();\n String date = \"\";\n if (cal.get(Calendar.DAY_OF_YEAR) == current.get(Calendar.DAY_OF_YEAR)) {\n date = getResources().getString(R.string.content_today) + String.format(\" %02d:%02d\", cal.get(Calendar.HOUR_OF_DAY), cal.get(Calendar.MINUTE));\n } else if ((cal.get(Calendar.DAY_OF_YEAR) - 1) == current.get(Calendar.DAY_OF_YEAR)) {\n date = getResources().getString(R.string.content_yesterday) + String.format(\" %02d:%02d\", cal.get(Calendar.HOUR_OF_DAY), cal.get(Calendar.MINUTE));\n } else if ((cal.get(Calendar.DAY_OF_YEAR) - 2) == current.get(Calendar.DAY_OF_YEAR)\n && getResources().getConfiguration().locale.equals(new Locale(\"vn\"))) {\n date = getResources().getString(R.string.content_before_yesterday) + String.format(\" %02d:%02d\", cal.get(Calendar.HOUR_OF_DAY), cal.get(Calendar.MINUTE));\n } else {\n date = String.format(\"%02d-%02d-%02d %02d:%02d\", mCal.get(Calendar.DAY_OF_MONTH), mCal.get(Calendar.MONTH) + 1, mCal.get(Calendar.YEAR), cal.get(Calendar.HOUR_OF_DAY), cal.get(Calendar.MINUTE));\n }\n\n return date;\n }", "public static String formatDate(Calendar calDate)\r\n\t{\r\n\t\tint intDate = calDate.get(Calendar.DAY_OF_MONTH);\r\n\t\tString dateSuffix = getDateSuffix(intDate);\r\n\t\treturn getCalendarMonthString(calDate.get(Calendar.MONTH))+\" \"+ intDate + dateSuffix + \" \" + calDate.get(Calendar.YEAR);\r\n\t}", "private String formatDate(Date dateObject) {\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"LLL dd, yyyy\");\n return dateFormat.format(dateObject);\n }", "private String formatDate(Date dateObject) {\r\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"LLL dd, yyyy\");\r\n return dateFormat.format(dateObject);\r\n }", "java.lang.String getStartDateYYYYMMDD();", "public String convertDayToString(Date date) {\n SimpleDateFormat formatDate = new SimpleDateFormat(\"yyyy-MM-dd\");\n return formatDate.format(date);\n }", "public static String dateToString(Date date){\r\n SimpleDateFormat df = new SimpleDateFormat(\"dd/MM/yyyy\");\r\n return df.format(date);\r\n }", "public String getFormatedDate() {\n DateFormat displayFormat = new SimpleDateFormat(\"EEEE', ' dd. MMMM yyyy\", Locale.GERMAN);\n return displayFormat.format(mEvent.getTime());\n }", "public String formatCalDate(Calendar cal) {\n if (cal != null) return SDF_TYPE_1.format(cal.getTime());\n return \"\";\n }", "public String dar_fecha(){\n Date date = new Date();\n DateFormat dateFormat = new SimpleDateFormat(\"dd/MM/yyyy\");\n return dateFormat.format(date).toString();\n\n }", "private String formatDate(Date date) {\n String resultDate;\n SimpleDateFormat dateFormat;\n dateFormat = new SimpleDateFormat(\"dd/MM/yyyy\");\n resultDate = dateFormat.format(date);\n return resultDate;\n }", "public static String formatDate(Date date) {\n\t\tString newstring = new SimpleDateFormat(\"MM-dd-yyyy\").format(date);\n\t\treturn newstring;\n\t}", "public String ConvertDate(){\r\n//\t\tDate date=JavaUtils.getSystemDate();\r\n//\t DateFormat df = new SimpleDateFormat(\"yyyy/MM/dd\");\r\n\t String pattern = \"yyyy-MM-dd\";\r\n\t SimpleDateFormat simpleDateFormat = new SimpleDateFormat(pattern);\r\n\r\n\t String date = simpleDateFormat.format(new Date());\r\n//\t System.out.println(date);\r\n\t \r\n//\t String s = df.format(date);\r\n//\t String result = s;\r\n//\t try {\r\n//\t date=df.parse(result);\r\n//\t } catch (ParseException e) {\r\n//\t // TODO Auto-generated catch block\r\n//\t e.printStackTrace();\r\n//\t }\r\n\t return date;\r\n\t }", "public static String formatDateToDD_MM_YY_hh_mm(Calendar calDate)\r\n\t{\r\n\t\tint day = calDate.get(Calendar.DAY_OF_MONTH);\r\n\t\tint month = calDate.get(Calendar.MONTH)+1;\r\n\t\tString year = String.valueOf(calDate.get(Calendar.YEAR)).substring(2);\r\n\t\tint hour = calDate.get(Calendar.HOUR_OF_DAY);\r\n\t\tint minute = calDate.get(Calendar.MINUTE);\r\n\t\t\r\n\t\treturn appendLeadingZero(day) + \"/\" + appendLeadingZero(month) + \"/\" + year + \" \" + appendLeadingZero(hour) + \":\" + appendLeadingZero(minute);\r\n\t}", "private String dateToString(Date d){\r\n\t\tSimpleDateFormat fmt = new SimpleDateFormat(DATE_FORMAT);\r\n\t\treturn fmt.format(d);\r\n\t}", "private String formatDate(Date dateObject) {\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"LLL dd, yyyy\", Locale.getDefault());\n return dateFormat.format(dateObject);\n }", "public static String formatDate(String date){\n String formatedDate = date;\n if (!date.matches(\"[0-9]{2}-[0-9]{2}-[0-9]{4}\")){\n if (date.matches(\"[0-9]{1,2}/[0-9]{1,2}/([0-9]{2}|[0-9]{4})\"))\n formatedDate = date.replace('/', '-');\n if (date.matches(\"[0-9]{1,2}.[0-9]{1,2}.([0-9]{2}|[0-9]{4})\")){\n if (formatedDate.matches(\"[0-9]{1}.[0-9]{1,2}.([0-9]{2}|[0-9]{4})\"))\n formatedDate = \"0\" + formatedDate;\n if (formatedDate.matches(\"[0-9]{2}.[0-9]{1}.([0-9]{2}|[0-9]{4})\"))\n formatedDate = formatedDate.substring(0, 3) + \"0\" + \n formatedDate.substring(3);\n if (formatedDate.matches(\"[0-9]{2}.[0-9]{2}.[0-9]{2}\")){\n String thisYear = String.valueOf(LocalDate.now().getYear());\n String century = thisYear.substring(0,2);\n /* If the last two digits of the date are larger than the two last digits of \n * the current date, then we can suppose that the year corresponds to the last \n * century.\n */ \n if (Integer.valueOf(formatedDate.substring(6)) > Integer.valueOf(thisYear.substring(2)))\n century = String.valueOf(Integer.valueOf(century) - 1);\n formatedDate = formatedDate.substring(0, 6) + century +\n formatedDate.substring(6); \n }\n }\n }\n return formatedDate;\n }", "public String DateFormatted(){\n\t\tSimpleDateFormat simDate = new SimpleDateFormat(\"E, dd/MM/yy hh:mm:ss a\");\n\t\treturn simDate.format(date.getTime());\n\t}", "public String getDateString(Date date) {\n Calendar cal = Calendar.getInstance();\n\n cal.setTime(date);\n int year = cal.get(Calendar.YEAR);\n String month = String.format(\"%02d\", cal.get(Calendar.MONTH) + 1);\n String day = String.format(\"%02d\", cal.get(Calendar.DAY_OF_MONTH));\n return year + month + day;\n }", "public static String dateOnly() throws Exception {\n\t\tDateFormat dateFormat = new SimpleDateFormat(\"dd-MM-yyyy\");\n\t\t// get current date time with Date()\n\t\tDate date = new Date();\n\t\t// Now format the date\n\t\tString date1 = dateFormat.format(date);\n\t\t// System.out.println(date1);\n\t\treturn date1;\n\t}", "private String easyDateFormat(final String format) {\n Date today = new Date();\n SimpleDateFormat formatter = new SimpleDateFormat(format);\n String datenewformat = formatter.format(today);\n return datenewformat;\n }", "public static String getLegibleDate(Date date) {\n\n\t\tSimpleDateFormat simpleDateFormat = new SimpleDateFormat(\"dd/MM/yy\"); // \"d MMM yyyy hh:mm aaa\"\n\t\tString dateInit = simpleDateFormat.format(date);\n\n\t\n\n\t\treturn dateInit;\n\t}", "private void updateLabel() {\n String myFormat = \"dd-MM-YYYY\"; //In which you need put here\n SimpleDateFormat sdf = new SimpleDateFormat(myFormat, Locale.US);\n dateInput.setText(sdf.format(myCalendar.getTime()));\n }", "public String getFormatedDate(Date date) {\r\n\t\tSimpleDateFormat sdf=new SimpleDateFormat(\"dd/mm/yyyy\");\r\n\t\treturn sdf.format(date);\r\n\t}", "public static String getStrUtilDate(java.util.Date date){\n\t\tif(date==null)\n\t\t\treturn fechaNula();\n\t\tString strDate=\"\";\n\t\t\n\t\tif(getDia(date)<10)\n\t\t\tstrDate+=\"0\"+getDia(date);\n\t\telse\n\t\t\tstrDate+=getDia(date);\n\t\tif(getMes(date)<10)\n\t\t\tstrDate+=\"/\"+\"0\"+getMes(date);\n\t\telse\n\t\t\tstrDate+=\"/\"+getMes(date);\n\t\tstrDate+=\"/\"+getAnio(date);\n\t\treturn strDate;\n\t}", "String getDate();", "String getDate();", "public static String formatDateToDD_MM_YYYY_hh_mm(Calendar calDate)\r\n\t{\r\n\t\tint day = calDate.get(Calendar.DAY_OF_MONTH);\r\n\t\tint month = calDate.get(Calendar.MONTH)+1;\r\n\t\tString year = String.valueOf(calDate.get(Calendar.YEAR));\r\n\t\tint hour = calDate.get(Calendar.HOUR_OF_DAY);\r\n\t\tint minute = calDate.get(Calendar.MINUTE);\r\n\t\t\r\n\t\treturn appendLeadingZero(day) + \"/\" + appendLeadingZero(month) + \"/\" + year + \" \" + appendLeadingZero(hour) + \":\" + appendLeadingZero(minute);\r\n\t}", "public static String makeDateString(int day, int month, int year) {\r\n\t\t\r\n\t\treturn makeYearString(year) + \"-\" +\r\n\t\tmakeMonthString(month) + \"-\" +\r\n\t\tmakeDayString(day);\r\n\t\t\r\n\t}", "private void setDate() {\n java.util.Date d1 = new java.util.Date();\n SimpleDateFormat df = new SimpleDateFormat(\"YYYY-MM-dd\");\n String formateDate = df.format(d1);\n lblDate.setText(formateDate); \n }", "public String toString() {\r\n String date = month + \"/\" + day;\r\n return date;\r\n }", "@Override\n\tpublic String toString() {\n\t\ttry {\n\t\t\tSimpleDateFormat formatter = new SimpleDateFormat(\"MM/dd/yyyy\");\n\t\t\tDate date = formatter.parse(month + \"/\" + day + \"/\" + year);\n\n\t\t\treturn formatter.format(date);\n\t\t} catch (Exception e) {\n\t\t\tthrow new RuntimeException(e);\n\t\t}\n\t}", "public static String getFormattedMonthDay(String dateStr){\n\n Pattern fixDate = Pattern.compile(\"(\\\\d{4})(\\\\d{1,2})(\\\\d{1,2})\");\n Matcher correctDate = fixDate.matcher(dateStr);\n correctDate.find();\n\n String Nowiscorrect = String.format(\"%s/%s/%s\",\n correctDate.group(1),\n correctDate.group(2),\n correctDate.group(3));\n\n String MonthAndDay = currentDate.getdateWithMonthLetters(Nowiscorrect);\n\n\n Pattern rtl_CHARACTERS = Pattern.compile(\"^[۱-۹]+\");\n Matcher findTheYear = rtl_CHARACTERS.matcher(MonthAndDay);\n boolean isDone = findTheYear.find();\n\n return isDone ? findTheYear.replaceAll(\"\") : \"\";\n\n }", "public static String formatDateToString(Date dateObj) {\n return formatDateToString(dateObj, DATE_FORMAT.DEFAULT);\n }", "public String toString() {\n\treturn String.format(\"%d/%d/%d\", year, month, day);\t\r\n\t}", "private String leerFecha() {\n\t\ttry {\n\t\t\tSimpleDateFormat sdf = new SimpleDateFormat(\"YYYY/MM/dd\");\n\t\t\treturn sdf.format(txtFecha.getDate());\n\t\t} catch (Exception e) {\n\t\t\tJOptionPane.showMessageDialog(this, \"Seleccione una fecha válida\", \"Aviso\", 2);\n\t\t\treturn null;\n\t\t}\n\t}", "private static Date dateToString(Date start) {\n\t\treturn start;\n\t}", "public static String dateToString(Date date)\r\n/* 19: */ {\r\n/* 20: 23 */ return sdfDate.format(date);\r\n/* 21: */ }", "public static String getDate()\n {\n Date date = new Date();\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"yyyy-MM-dd\");\n return dateFormat.format(date);\n }", "public String getEntryDateString() {\n SimpleDateFormat sdf = new SimpleDateFormat(\"yyyy MMM dd\");\n return sdf.format(entryDate.getTime());\n }", "public String retornaData(){\n\t\tCalendar calendar = new GregorianCalendar();\n\t\tSimpleDateFormat df = new SimpleDateFormat(\"dd/MM/yyyy\");\n\t\tDate date = new Date();\n\t\tcalendar.setTime(date);\n\t\treturn df.format(calendar.getTime());\n\t}", "public String convertDateToString(Date date) {\n\t\tString dateTime = SDF.format(date);\n\t\treturn dateTime;\t\n\t}", "public static String getDate(Date date)\n\t{\n\t\treturn getFormatString(date, getDateFormat());\n\t}", "java.lang.String getFromDate();", "@Override\n public void onDateSet(DatePicker view, int year, int monthOfYear,\n int dayOfMonth) {\n\n myCalendar.set(Calendar.YEAR, year);\n myCalendar.set(Calendar.MONTH, monthOfYear);\n myCalendar.set(Calendar.DAY_OF_MONTH, dayOfMonth);\n\n String myFormat = \"dd.MM.yyyy\"; //In which you need put here\n SimpleDateFormat sdf = new SimpleDateFormat(myFormat, Locale.US);\n\n dateInput.setText(sdf.format(myCalendar.getTime()));\n }", "String formatDateCondition(Date date);", "public static String getYYYYMMDD()\r\n/* 65: */ {\r\n/* 66: 81 */ String nowTime = \"\";\r\n/* 67: 82 */ Date now = new Date();\r\n/* 68: 83 */ SimpleDateFormat formatter = new SimpleDateFormat(\"yyyyMMdd\");\r\n/* 69: 84 */ nowTime = formatter.format(now);\r\n/* 70: 85 */ return nowTime;\r\n/* 71: */ }", "public static String formatDate(Date date) {\n final SimpleDateFormat formatter = new SimpleDateFormat(\"MM-dd-yyyy\");\n return formatter.format(date);\n }", "public static String getDisplayDateFormat(Date val) {\n\n\t\tif (val != null) {\n\n\t\t\tSimpleDateFormat format = new SimpleDateFormat(\"dd/MM/yyyy\");\n\t\t\treturn \"\" + format.format(val);\n\n\t\t} else {\n\n\t\t\treturn null;\n\n\t\t}\n\n\t}", "public final String obtenerFechaFormateada() {\n DateTimeFormatter formatter = DateTimeFormatter.ofPattern(\"dd/MMM/yyyy\");\n return fechaDeLaVisita.get().format(formatter);\n }", "public static String toStringFormat_4(Date date) {\r\n\r\n\t\treturn dateToString(date, DATE_FORMAT_4);\r\n\t}", "public String getDate() {\n\t\tSimpleDateFormat sdf = new SimpleDateFormat(\"yyyy-MM-dd\");\n\t\treturn sdf.format(txtDate.getDate());\n\t}", "void showdate(){\n \n Date d = new Date();\n SimpleDateFormat s = new SimpleDateFormat(\"yyyy-MM-dd\");\n jLabel4.setText(s.format(d));\n}", "public String toString() {\r\n\t\treturn String.format(\"%02d/%02d/%02d\", month, day, year);\r\n\r\n\t}", "public static String getStrDate(Date date) {\n //TODO get date\n SimpleDateFormat formatter;\n if (DateUtils.isToday(date.getTime())) {\n formatter = new SimpleDateFormat(\"HH:mm\");\n return formatter.format(date);\n }\n formatter = new SimpleDateFormat(\"MMM dd\");\n return formatter.format(date);\n }", "private String getDate(Calendar c) {\n\t\t\n\t\tStringBuffer sb = new StringBuffer();\n\t\t\n\t\tsb.append(EventHelper.getMonth(c));\n\t\tsb.append(\" \");\n\t\tsb.append(EventHelper.getDate(c));\n\t\t\n\t\treturn sb.toString();\n\t\t\n\t}", "public String format (Date date , String dateFormat) ;", "public static String ssnToDateOfBirth(String ssn) {\n String dateOfBirth = ssn.substring(0, 6);\n String dateOfBirthFormatted = \"\";\n for (int i = 0; i < dateOfBirth.length(); i++) {\n dateOfBirthFormatted += dateOfBirth.charAt(i);\n if (i == 1 || i == 3) {\n dateOfBirthFormatted += \".\";\n }\n }\n return dateOfBirthFormatted;\n }", "private String formatDueDate(Date date) {\n\t\t//TODO locale formatting via ResourceLoader\n\t\t\n\t\tif(date == null) {\n\t\t\treturn getString(\"label.studentsummary.noduedate\");\n\t\t}\n\t\t\n\t\tSimpleDateFormat df = new SimpleDateFormat(\"dd/MM/yy\");\n \treturn df.format(date);\n\t}", "public static String getDisplayFullDateFormat(Date val) {\n\n\t\tif (val != null) {\n\n\t\t\tSimpleDateFormat format = new SimpleDateFormat(\n\t\t\t\t\t\"EEEE, MMMMM dd, yyyy\");\n\t\t\treturn \"\" + format.format(val);\n\n\t\t} else {\n\n\t\t\treturn null;\n\n\t\t}\n\n\t}", "@Method(selector = \"stringFromDate:toDate:\")\n public native String format(NSDate fromDate, NSDate toDate);", "public String getDateString() {\n DateFormat format = DateFormat.getDateInstance(DateFormat.FULL, Locale.getDefault());\n return format.format(mDate);\n }", "public String getPrintFormattedDate() {\n return this.date.format(DateTimeFormatter.ofPattern(\"MMM d yyyy\"));\n }", "public static String makeDayString(int day) { return ((day < 10) ? \"0\" + day : \"\" + day); }", "public String getDate()\n {\n return day + \"/\" + month + \"/\" + year;\n }", "private String formatDate(String dateString) {\n DateTimeFormatter dateTimeFormatter = DateTimeFormatter.ofPattern(\"LLL dd, yyyy\");\n LocalDate localDate = LocalDate.parse(dateString.substring(0, 10));\n return dateTimeFormatter.format(localDate);\n }", "private String formatDate(String dateStr) {\n try {\n SimpleDateFormat fmt = new SimpleDateFormat(Properties.DATE_FORMAT_ALL);\n Date date = fmt.parse(dateStr);\n SimpleDateFormat fmtOut = new SimpleDateFormat(Properties.DATE_FORMAT);\n return fmtOut.format(date);\n } catch (ParseException e) {\n System.out.println( Properties.K_WARNING + \" \" + e.getMessage());\n }\n return \"\";\n }", "public String getUserDateString() {\n\t\tString[] tmpArr = this.getUserDate();\n\t\tString year = tmpArr[0];\n\t\tString month = tmpArr[1];\n\t\tString day = tmpArr[2];\n\t\tString out = year + \"/\" + month + \"/\" + day;\n\t\treturn out;\n\t}", "public static String date_d(String sourceDate,String format) throws ParseException {\n SimpleDateFormat sdf_ = new SimpleDateFormat(\"yyyy-MM-dd\");\n SimpleDateFormat sdfNew_ = new SimpleDateFormat(format);\n return sdfNew_.format(sdf_.parse(sourceDate));\n }", "private static String setDate() {\n mDate = new Date();\n DateFormat dateFormat = DateFormat.getDateInstance();\n String dateString = dateFormat.format(mDate);\n return dateString;\n }" ]
[ "0.69854796", "0.66807574", "0.66705656", "0.66182494", "0.65712446", "0.6551308", "0.6519945", "0.6500068", "0.63469803", "0.6327338", "0.6327305", "0.6294213", "0.62934506", "0.6251062", "0.6245724", "0.624113", "0.62329984", "0.62311095", "0.6224563", "0.6215999", "0.6206459", "0.6206291", "0.62056744", "0.6204663", "0.62031734", "0.61924654", "0.6173605", "0.6165419", "0.6152043", "0.6150788", "0.6146909", "0.6145014", "0.6137472", "0.61295223", "0.61229056", "0.61145747", "0.61085165", "0.60913694", "0.607701", "0.6069872", "0.6064972", "0.6063998", "0.60596806", "0.6056072", "0.60429144", "0.60373604", "0.60345846", "0.60333145", "0.60332805", "0.60252327", "0.6023338", "0.6011445", "0.6004349", "0.5981567", "0.5978965", "0.5967846", "0.5963029", "0.5963029", "0.59408456", "0.5923693", "0.591773", "0.5917531", "0.5908556", "0.59040445", "0.5899249", "0.58953226", "0.5895045", "0.58944243", "0.5893253", "0.5890727", "0.5889684", "0.5879028", "0.5878633", "0.5878176", "0.5876349", "0.5872872", "0.58626217", "0.5854499", "0.5842121", "0.58350873", "0.5815547", "0.58109796", "0.5810677", "0.57987773", "0.57942414", "0.57925916", "0.57903266", "0.57891595", "0.57823783", "0.57808477", "0.57806987", "0.5780581", "0.57787746", "0.5773685", "0.5762981", "0.57597846", "0.5758321", "0.5746918", "0.57446605", "0.57423735", "0.5738401" ]
0.0
-1
Create a calender instance to create a date object with the pattern hh:mm to get a String like that of the given hours and minute. Finally add the formatting at the end and updateFood the view Example: 06:25 AM
@Override public void onTimeSet(TimePicker view, int hourOfDay, int minute) { Calendar calendar = Calendar.getInstance(); calendar.set(0, 0, 0, hourOfDay, minute, 0); Date date = calendar.getTime(); SimpleDateFormat sdf = new SimpleDateFormat("hh.mm aa", Locale.getDefault()); mBinding.time.setText(sdf.format(date)); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void actionPerformed(ActionEvent ae){\n Date date = new Date();\n //instantiate new Date object\n\n DateFormat format = new SimpleDateFormat(\"E, MMM d y HH:mm:ss\");\n //set format of clock\n\n DateFormat otherFormat = new SimpleDateFormat(\"E, MMM, d y KK:mm:ss a\");\n //12 hour time\n\n String dateTime = format.format(date);\n //formatting date object using format template\n\n String otherDateTime = otherFormat.format(date);\n\n clockLabelOne.setText(dateTime);\n //setting clock text to formatted String\n }", "private void updateTime() \r\n\t {\r\n\t\t \r\n\t\t \tif(Hours.getValue() < 12)\r\n\t\t \t{\r\n\t\t \t\tdisplayString = Hours.getDisplayValue() + \":\" + Minutes.getDisplayValue() + \":\" + Seconds.getDisplayValue() + \" am\";\r\n\t\t System.out.println(displayString);\r\n\t\t \t}\r\n\t\t \t\r\n\t\t \telse if (Hours.getValue() > 12 && Hours.getValue() < 24 )\r\n\t\t \t{\r\n\t\t \t\tdisplayString = Hours.getDisplayValue() + \":\" + Minutes.getDisplayValue() + \":\" + Seconds.getDisplayValue() + \" pm\";\r\n\t\t System.out.println(displayString);\r\n\t\t \t}\r\n\t }", "private void updateTimeTxtV()\n {\n String timeFormat =\"hh:mm aaa\";//12:08 PM\n SimpleDateFormat stf = new SimpleDateFormat(timeFormat, Locale.CANADA);\n timeStr = stf.format(cal.getTime());\n timeTxtV.setText(timeStr);\n\n //unix datetime for saving in db\n dateTimeUnix = cal.getTimeInMillis() / 1000L;\n }", "public static String TimeFormate() {\n\t\tString time;\n\t\tSimpleDateFormat dateFormat1 = new SimpleDateFormat();\n\t dateFormat1.setTimeZone(TimeZone.getTimeZone(\"US/Eastern\"));\n\t Calendar cal = Calendar.getInstance();\n\t cal.add(Calendar.MINUTE, 3);\n String n=dateFormat1.format(cal.getTime());\n //n=\"03/09/20 8:30 AM\";\n System.out.println(\"Full Date = \" +n);\n int colonindex=n.indexOf(\":\");\n //System.out.println(\": placed= \" +colonindex);\n //String tt =n.substring(colonindex, n.length());\n //System.out.println(\"tt= \" +tt);\n String tt1 =n.substring(colonindex-2,colonindex-1);\n System.out.println(\"tt1= \" +tt1);\n if(tt1.equals(\"1\")) {\n \t time=n.substring(colonindex-2, n.length());\n \t System.out.println(\"Time with two digits in hours= \" +time);\n }\n else {\n \t time=n.substring(colonindex-1, n.length());\n \t System.out.println(\"Time with one digit in hours= \" +time);\n }\n return time;\n\t}", "private void updateStartTime() {\n Date date = startTimeCalendar.getTime();\n String startTime = new SimpleDateFormat(\"HH:mm\").format(date);\n startHourText.setText(startTime);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t12Hour12 = hourOfDay1;\n t12Minute12 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t12Hour12, t12Minute12);\n //set selected time on text view\n\n\n timeE6 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime6.setText(timeE6);\n }", "public void actionPerformed(ActionEvent ae){\n Date date = new Date();\n //instantiate new Date object\n\n DateFormat otherFormat = new SimpleDateFormat(\"E, MMM, d y K:mm:ss a\");\n //12 hour time\n\n String otherDateTime = otherFormat.format(date);\n\n clockLabelTwo.setText(otherDateTime);\n //setting clock text to formatted String\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t36Hour36 = hourOfDay1;\n t36Minute36 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t36Hour36, t36Minute36);\n //set selected time on text view\n\n\n timeE18 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime18.setText(timeE18);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t46Hour46 = hourOfDay1;\n t46Minute46 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t46Hour46, t46Minute46);\n //set selected time on text view\n\n\n timeE23 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime23.setText(timeE23);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t42Hour42 = hourOfDay1;\n t42Minute42 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t42Hour42, t42Minute42);\n //set selected time on text view\n\n\n timeE21 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime21.setText(timeE21);\n }", "private void getIntialCalender() {\n\n\t\ttry {\n\n\t\t\tc = Calendar.getInstance();\n\t\t\tString[] fields = Global_variable.str_booking_date.split(\"[-]\");\n\n\t\t\tString str_year = fields[0];\n\t\t\tString str_month = fields[1];\n\t\t\tString str_day = fields[2];\n\n\t\t\tSystem.out.println(\"!!!!\" + fields[0]);\n\t\t\tSystem.out.println(\"!!!!\" + fields[1]);\n\t\t\tSystem.out.println(\"!!!!!\" + fields[2]);\n\n\t\t\tif (str_year.length() != 0) {\n\t\t\t\tyear = Integer.parseInt(str_year);\n\t\t\t} else {\n\t\t\t\tyear = c.get(Calendar.YEAR);\n\t\t\t}\n\n\t\t\tif (str_month.length() != 0) {\n\t\t\t\tmonth = Integer.parseInt(str_month) - 1;\n\t\t\t} else {\n\t\t\t\tmonth = c.get(Calendar.MONTH);\n\t\t\t}\n\n\t\t\tif (str_year.length() != 0) {\n\t\t\t\tday = Integer.parseInt(str_day);\n\t\t\t} else {\n\t\t\t\tday = c.get(Calendar.DAY_OF_MONTH);\n\t\t\t}\n\n\t\t\tString[] fields1 = Global_variable.str_booking_time.split(\"[:]\");\n\n\t\t\tString str_hour = fields1[0];\n\t\t\tString str_minutes = fields1[1];\n\n\t\t\tSystem.out.println(\"!!!!!\" + fields1[0]);\n\t\t\tSystem.out.println(\"!!!!!\" + fields1[1]);\n\n\t\t\tif (str_hour.length() != 0) {\n\t\t\t\thour = Integer.parseInt(str_hour);\n\t\t\t} else {\n\t\t\t\thour = c.get(Calendar.HOUR_OF_DAY);\n\t\t\t}\n\n\t\t\tif (str_minutes.length() != 0) {\n\t\t\t\tminutes = Integer.parseInt(str_minutes);\n\t\t\t} else {\n\t\t\t\tminutes = c.get(Calendar.MINUTE);\n\t\t\t}\n\n\t\t\tcurrDate = new java.sql.Date(System.currentTimeMillis());\n\n\t\t\tSimpleDateFormat sdf = new SimpleDateFormat(\"yyyy-MM-dd\");\n\t\t\tCalendar c1 = Calendar.getInstance();\n\t\t\tc1.setTime(new Date()); // Now use today date.\n\t\t\tc1.add(Calendar.DATE, 30); // Adding 30 days\n\t\t\toutput = sdf.format(c1.getTime());\n\t\t\tSystem.out.println(\"!!!!!!!!!!!!!!!\" + output);\n\n\t\t} catch (NullPointerException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t}", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t20Hour20 = hourOfDay1;\n t20Minute20 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t20Hour20, t20Minute20);\n //set selected time on text view\n\n\n timeE10 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime10.setText(timeE10);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t45Hour45 = hourOfDay1;\n t45Minute45 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t45Hour45, t45Minute45);\n //set selected time on text view\n\n\n timeS23 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime23.setText(timeS23);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t24Hour24 = hourOfDay1;\n t24Minute24 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t24Hour24, t24Minute24);\n //set selected time on text view\n\n\n timeE12 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime12.setText(timeE12);\n }", "private String formatTime(Date dateObject) {\n @SuppressLint(\"SimpleDateFormat\") SimpleDateFormat timeFormat = new SimpleDateFormat(\"h:mm a\");\n return timeFormat.format(dateObject);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t6Hour6 = hourOfDay1;\n t6Minute6 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t6Hour6, t6Minute6);\n //set selected time on text view\n\n\n timeE3 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime3.setText(timeE3);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t10Hour10 = hourOfDay1;\n t10Minute10 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t10Hour10, t10Minute10);\n //set selected time on text view\n\n\n timeE5 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime5.setText(timeE5);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t23Hour23 = hourOfDay1;\n t23Minute23 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t23Hour23, t23Minute23);\n //set selected time on text view\n\n\n timeS12 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime12.setText(timeS12);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t43Hour43 = hourOfDay1;\n t43Minute43 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t43Hour43, t43Minute43);\n //set selected time on text view\n\n\n timeS22 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime22.setText(timeS22);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t18Hour18 = hourOfDay1;\n t18Minute18 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t18Hour18, t18Minute18);\n //set selected time on text view\n\n\n timeE9 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime9.setText(timeE9);\n }", "private String formatTime(Date dateObject) {\r\n SimpleDateFormat timeFormat = new SimpleDateFormat(\"h:mm a\");\r\n return timeFormat.format(dateObject);\r\n }", "@Override\r\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n selected_hour = hourOfDay;\r\n selected_minute = minute;\r\n if (hourOfDay>=12){\r\n period=\" PM\";\r\n }\r\n hourOfDay%=12;\r\n if(hourOfDay==0)hourOfDay=12;\r\n s= String.format(\"%02d:%02d %s\", hourOfDay, minute, period);\r\n SpannableString ss1= new SpannableString(s);\r\n ss1.setSpan(new RelativeSizeSpan(3f), 0,5, 0); // set size\r\n tv7.setText(ss1);\r\n //tv7.setText(String.format(\"%02d:%02d\", hourOfDay, minute));\r\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t40Hour40 = hourOfDay1;\n t40Minute40 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t40Hour40, t40Minute40);\n //set selected time on text view\n\n\n timeE20 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime20.setText(timeE20);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t11Hour11 = hourOfDay1;\n t11Minute11 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t11Hour11, t11Minute11);\n //set selected time on text view\n\n\n timeS6 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime6.setText(timeS6);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t35Hour35 = hourOfDay1;\n t35Minute35 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t35Hour35, t35Minute35);\n //set selected time on text view\n\n\n timeS18 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime18.setText(timeS18);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t22Hour22 = hourOfDay1;\n t22Minute22 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t22Hour22, t22Minute22);\n //set selected time on text view\n\n\n timeE11 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime11.setText(timeE11);\n }", "public String morningMeeting(){\n return \"accountants have meetings beginning at 9:15 AM and run until 8:45 AM\";\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t13Hour13 = hourOfDay1;\n t13Minute13 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t13Hour13, t13Minute13);\n //set selected time on text view\n\n\n timeS7 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime7.setText(timeS7);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t50Hour50 = hourOfDay1;\n t50Minute50 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t50Hour50, t50Minute50);\n //set selected time on text view\n\n\n timeE25 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime25.setText(timeE25);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t44Hour44 = hourOfDay1;\n t44Minute44 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t44Hour44, t44Minute44);\n //set selected time on text view\n\n\n timeE22 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime22.setText(timeE22);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t21Hour21 = hourOfDay1;\n t21Minute21 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t21Hour21, t21Minute21);\n //set selected time on text view\n\n\n timeS11 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime11.setText(timeS11);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t48Hour48 = hourOfDay1;\n t48Minute48 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t48Hour48, t48Minute48);\n //set selected time on text view\n\n\n timeE24 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime24.setText(timeE24);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t14Hour14 = hourOfDay1;\n t14Minute14 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t14Hour14, t14Minute14);\n //set selected time on text view\n\n\n timeE7 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime7.setText(timeE7);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t34Hour34 = hourOfDay1;\n t34Minute34 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t34Hour34, t34Minute34);\n //set selected time on text view\n\n\n timeE17 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime17.setText(timeE17);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t47Hour47 = hourOfDay1;\n t47Minute47 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t47Hour47, t47Minute47);\n //set selected time on text view\n\n\n timeS24 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime24.setText(timeS24);\n }", "private String formatTime(Date dateObject)\n {\n SimpleDateFormat timeFormat = new SimpleDateFormat(\"h:mm a\");\n timeFormat.setTimeZone(Calendar.getInstance().getTimeZone());\n return timeFormat.format(dateObject);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t41Hour41 = hourOfDay1;\n t41Minute41 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t41Hour41, t41Minute41);\n //set selected time on text view\n\n\n timeS21 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime21.setText(timeS21);\n }", "private String formatTime(Date dateObject) {\n SimpleDateFormat timeFormat = new SimpleDateFormat(\"h:mm a\", Locale.getDefault());\n return timeFormat.format(dateObject);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t26Hour26 = hourOfDay1;\n t26Minute26 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t26Hour26, t26Minute26);\n //set selected time on text view\n\n\n timeE13 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime13.setText(timeE13);\n }", "@Override\n\tpublic void onCreate() {\n\t\t\n\t\t \n\t\tfinal Calendar ca = Calendar.getInstance();\n\t\tint mHour = ca.get(Calendar.HOUR_OF_DAY);\n\t\tint mMinute = ca.get(Calendar.MINUTE);\n\t\tStringBuilder s1=new StringBuilder().append(pad(mHour)).append(\":\").append(pad(mMinute));\n\t\t\n\t todaytime=(String)s1.toString();\n\t\t\n\t\tsuper.onCreate();\n\t}", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t30Hour30 = hourOfDay1;\n t30Minute30 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t30Hour30, t30Minute30);\n //set selected time on text view\n\n\n timeE15 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime15.setText(timeE15);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t27Hour27 = hourOfDay1;\n t27Minute27 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t27Hour27, t27Minute27);\n //set selected time on text view\n\n\n timeS14 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime14.setText(timeS14);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t4Hour4 = hourOfDay1;\n t4Minute4 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t4Hour4, t4Minute4);\n //set selected time on text view\n\n\n timeE2 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime2.setText(timeE2);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t19Hour19 = hourOfDay1;\n t19Minute19 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t19Hour19, t19Minute19);\n //set selected time on text view\n\n\n timeS10 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime10.setText(timeS10);\n }", "private void setClock(int day, int hour, int minute) {\n String dayString;\n switch(day) {\n case 0: dayString = \"Maandag\";\n break;\n case 1: dayString = \"Dinsdag\";\n break;\n case 2: dayString = \"Woensdag\";\n break;\n case 3: dayString = \"Donderdag\";\n break;\n case 4: dayString = \"Vrijdag\";\n break;\n case 5: dayString = \"Zaterdag\";\n break;\n case 6: dayString = \"Zondag\";\n break;\n default: dayString = \"Ongeldige dag\";\n break;\n }\n //\tLaat de tijd 02 zijn in plaats van 2\n String hourString = String.format(\"%02d\", hour);\n String minuteString = String.format(\"%02d\", minute);\n clock.setText(\"<html><h2>\"+dayString + \" \" + hourString + \":\" + minuteString+\"</h2></html>\");\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t33Hour33 = hourOfDay1;\n t33Minute33 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t33Hour33, t33Minute33);\n //set selected time on text view\n\n\n timeS17 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime17.setText(timeS17);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t32Hour32 = hourOfDay1;\n t32Minute32 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t32Hour32, t32Minute32);\n //set selected time on text view\n\n\n timeE16 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime16.setText(timeE16);\n }", "private void setTimeOfDay(){\n Calendar calendar = Calendar.getInstance();\n int timeOfDay = calendar.get(Calendar.HOUR_OF_DAY);\n if(timeOfDay >= 0 && timeOfDay < 12){\n greetings.setText(\"Good Morning\");\n }else if(timeOfDay >= 12 && timeOfDay < 16){\n greetings.setText(\"Good Afternoon\");\n }else if(timeOfDay >= 16 && timeOfDay < 23){\n greetings.setText(\"Good Evening\");\n }\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t5Hour5 = hourOfDay1;\n t5Minute5 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t5Hour5, t5Minute5);\n //set selected time on text view\n\n\n timeS3 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime3.setText(timeS3);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t28Hour28 = hourOfDay1;\n t28Minute28 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t28Hour28, t28Minute28);\n //set selected time on text view\n\n\n timeE14 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime14.setText(timeE14);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t8Hour8 = hourOfDay1;\n t8Minute8 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t8Hour8, t8Minute8);\n //set selected time on text view\n\n\n timeE4 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime4.setText(timeE4);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t16Hour16 = hourOfDay1;\n t16Minute16 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t16Hour16, t16Minute16);\n //set selected time on text view\n\n\n timeE8 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime8.setText(timeE8);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t17Hour17 = hourOfDay1;\n t17Minute17 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t17Hour17, t17Minute17);\n //set selected time on text view\n\n\n timeS9 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime9.setText(timeS9);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t7Hour7 = hourOfDay1;\n t7Minute7 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t7Hour7, t7Minute7);\n //set selected time on text view\n\n\n timeS4 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime4.setText(timeS4);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t2Hour2 = hourOfDay1;\n t2Minute2 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t2Hour2, t2Minute2);\n //set selected time on text view\n\n\n timeE1 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime1.setText(timeE1);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t39Hour39 = hourOfDay1;\n t39Minute39 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t39Hour39, t39Minute39);\n //set selected time on text view\n\n\n timeS20 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime20.setText(timeS20);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t1Hour1 = hourOfDay1;\n t1Minute1 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t1Hour1, t1Minute1);\n //set selected time on text view\n\n\n timeS1 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime1.setText(timeS1);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t25Hour25 = hourOfDay1;\n t25Minute25 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t25Hour25, t25Minute25);\n //set selected time on text view\n\n\n timeS13 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime13.setText(timeS13);\n }", "public String calculateHour() {\n\t\tString hora;\n\t\tString min;\n\t\tString seg;\n\t\tString message;\n\t\tCalendar calendario = new GregorianCalendar();\n\t\tDate horaActual = new Date();\n\t\tcalendario.setTime(horaActual);\n\n\t\thora = calendario.get(Calendar.HOUR_OF_DAY) > 9 ? \"\" + calendario.get(Calendar.HOUR_OF_DAY)\n\t\t\t\t: \"0\" + calendario.get(Calendar.HOUR_OF_DAY);\n\t\tmin = calendario.get(Calendar.MINUTE) > 9 ? \"\" + calendario.get(Calendar.MINUTE)\n\t\t\t\t: \"0\" + calendario.get(Calendar.MINUTE);\n\t\tseg = calendario.get(Calendar.SECOND) > 9 ? \"\" + calendario.get(Calendar.SECOND)\n\t\t\t\t: \"0\" + calendario.get(Calendar.SECOND);\n\n\t\tmessage = hora + \":\" + min + \":\" + seg;\n\t\treturn message;\n\n\t}", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t9Hour9 = hourOfDay1;\n t9Minute9 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t9Hour9, t9Minute9);\n //set selected time on text view\n\n\n timeS5 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime5.setText(timeS5);\n }", "public static String ShowDate(){\n Date date = new Date();\n SimpleDateFormat sdf = new SimpleDateFormat(\"HH:mm:ss.SS a\");\n String HH_MM = sdf.format(date);\n return HH_MM;\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t3Hour3 = hourOfDay1;\n t3Minute3 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t3Hour3, t3Minute3);\n //set selected time on text view\n\n\n timeS2 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime2.setText(timeS2);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t31Hour31 = hourOfDay1;\n t31Minute31 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t31Hour31, t31Minute31);\n //set selected time on text view\n\n\n timeS16 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime16.setText(timeS16);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t38Hour38 = hourOfDay1;\n t38Minute38 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t38Hour38, t38Minute38);\n //set selected time on text view\n\n\n timeE19 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime19.setText(timeE19);\n }", "public void PopulateHours(String day,String date){\n for(int i=8;i<=18;++i){\n String Id=Identifier(day)+\"\"+i;\n LinearLayout L=getLinearLayout(Id);\n L.removeAllViews();\n ArrayList<Booking>Hour=getBookings(i,date);\n if(!Hour.isEmpty()){\n for(int j=0;j<Hour.size();++j){\n Booking temp=Hour.get(j);\n LinearLayout t=(LinearLayout) View.inflate(this,R.layout.booking_textview,null);\n if(temp.Booked()) {\n String time = temp.getTime().substring(0, 5);\n String duration = \"\";\n int value = Integer.parseInt(time.substring(3, 5) )+ 15;\n\n int d=1;\n if (value < 60) {\n duration = time.substring(0, 2) + \":\" + value;\n\n } else {\n int nexthour = Integer.parseInt(time.substring(0, 2)) + 1;\n duration = \"\" + nexthour + \":00\";\n }\n TextView a = (TextView) t.findViewById(R.id.hourdivision);\n a.setText(\"APPOINTMENT\" + \"\\n\" + time + \"-\" + duration);\n\n L.addView(t);\n }\n }\n }\n\n else{\n LinearLayout t=(LinearLayout) View.inflate(this,R.layout.booking_textview,null);\n TextView a=(TextView)t.findViewById(R.id.hourdivision) ;\n a.setText(\"APPOINTMENT\"+\"\\n\"+\"9:15-9:30\");\n a.setTextColor(Color.TRANSPARENT);\n a.setVisibility(View.INVISIBLE);\n L.addView(t);}\n }\n\n // Allign();\n }", "@Override\n public void run() {\n\n SimpleDateFormat sdf = new SimpleDateFormat(\"hh:mm aa\",\n Locale.getDefault());\n String formattedTime = sdf.format(System.currentTimeMillis());\n tvAlarmTime.setText(formattedTime);\n\n tvAlarmTitle.setText(R.string.snoozed_alarm);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t37Hour37 = hourOfDay1;\n t37Minute37 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t37Hour37, t37Minute37);\n //set selected time on text view\n\n\n timeS19 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime19.setText(timeS19);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t49Hour49 = hourOfDay1;\n t49Minute49 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t49Hour49, t49Minute49);\n //set selected time on text view\n\n\n timeS25 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime25.setText(timeS25);\n }", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t29Hour29 = hourOfDay1;\n t29Minute29 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t29Hour29, t29Minute29);\n //set selected time on text view\n\n\n timeS15 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime15.setText(timeS15);\n }", "public void createDate(){\n SimpleDateFormat sdf = new SimpleDateFormat(\"yyyy_MM_dd\"); //TODO -HHmm si dejo diagonales separa bonito en dia, pero para hacer un armado de excel creo que debo hacer un for mas\n currentDateandTime = sdf.format(new Date());\n Log.e(TAG, \"todays date is: \"+currentDateandTime );\n\n}", "@Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n\n t15Hour15 = hourOfDay1;\n t15Minute15 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t15Hour15, t15Minute15);\n //set selected time on text view\n\n\n timeS8 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime8.setText(timeS8);\n }", "public static void main(String[] args) throws Exception {\n Calendar cal = Calendar.getInstance();\n SimpleDateFormat simpleformat = new SimpleDateFormat(\"E, dd MMM yyyy HH:mm:ss Z\");\n System.out.println(\"Today's date and time = \"+simpleformat.format(cal.getTime()));\n // displaying date\n simpleformat = new SimpleDateFormat(\"dd/MMMM/yyyy\");\n String str = simpleformat.format(new Date());\n System.out.println(\"Current Date = \"+str);\n // current time\n simpleformat = new SimpleDateFormat(\"HH:mm:ss\");\n String strTime = simpleformat.format(new Date());\n System.out.println(\"Current Time = \"+strTime);\n // displaying hour in HH format\n simpleformat = new SimpleDateFormat(\"HH\");\n String strHour = simpleformat.format(new Date());\n System.out.println(\"Hour in HH format = \"+strHour);\n\n\n\n //formato ideal\n simpleformat = new SimpleDateFormat(\"dd/MM/yyyy - HH:mm:ss\");\n String strTimeDay = simpleformat.format(new Date());\n System.out.println(\"Dia e Hora = \" + strTimeDay);\n\n }", "public void updateText() {\n\n dateText = dateFormat.format(c.getTime());\n timeText = timeFormat.format(c.getTime());\n dateEt.setText(dateText + \" \"+ timeText);\n}", "@Override\n public void onTimeSet(RadialPickerLayout view, int hourOfDay, int minute, int second) {\n String time = Integer.toString(hourOfDay) + \"-\" + Integer.toString(minute);\n txtTime.setText(time);\n\n //TODO why get wrong time?\n calendar.set(Calendar.HOUR, hourOfDay);\n calendar.set(Calendar.MINUTE, minute);\n\n }", "public String FormatTime(int hour, int minute) {\n\n String time;\n time = \"\";\n String formattedMinute;\n\n if (minute / 10 == 0) {\n formattedMinute = \"0\" + minute;\n } else {\n formattedMinute = \"\" + minute;\n }\n\n\n if (hour == 0) {\n time = \"12\" + \":\" + formattedMinute + \" AM\";\n } else if (hour < 12) {\n time = hour + \":\" + formattedMinute + \" AM\";\n } else if (hour == 12) {\n time = \"12\" + \":\" + formattedMinute + \" PM\";\n } else {\n int temp = hour - 12;\n time = temp + \":\" + formattedMinute + \" PM\";\n }\n\n\n return time;\n }", "public void addData() {\n if (daySchedule == null) {\n return;\n }\n int numTimes = daySchedule.size();\n TableLayout tl = findViewById(R.id.table);\n int chosenTime = MainActivity.hour * 60 + MainActivity.minute;\n if(chosenTime == 0)\n {\n Calendar now = Calendar.getInstance();\n chosenTime = now.get(Calendar.HOUR_OF_DAY) * 60 + now.get(Calendar.MINUTE);;\n }\n for (int i = 0; i < numTimes; i++) {\n TableRow tr = new TableRow(this);\n tr.setLayoutParams(getLayoutParams());\n Time t = daySchedule.get(i);\n if (!haverford) {\n if (Time.toMinutes(t.leaveBrynMawr()) > chosenTime) {\n Log.d(\"brynmawrtime\", String.valueOf(Time.toMinutes(t.leaveBrynMawr())));\n tr.addView(getTextView(i + 1, t.leaveBrynMawr(), Color.WHITE, Typeface.NORMAL, ContextCompat.getColor(this, R.color.colorAccent)));\n tr.addView(getTextView(i + numTimes, t.arriveHaverford(), Color.WHITE, Typeface.NORMAL, ContextCompat.getColor(this, R.color.colorAccent)));\n }\n } else {\n if (Time.toMinutes(t.leaveHaverford()) > chosenTime) {\n tr.addView(getTextView(i + 1, t.leaveHaverford(), Color.WHITE, Typeface.NORMAL, ContextCompat.getColor(this, R.color.colorAccent)));\n tr.addView(getTextView(i + numTimes, t.arriveBrynMawr(), Color.WHITE, Typeface.NORMAL, ContextCompat.getColor(this, R.color.colorAccent)));\n }\n }\n tl.addView(tr, getTblLayoutParams());\n }\n }", "@Override\n\t\t\t\t\t\t\tpublic void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n\t\t\t\t\t\t\t\tcalendar.set(Calendar.HOUR_OF_DAY,hourOfDay);\n\t\t\t\t\t\t\t\tcalendar.set(Calendar.MINUTE,minute);\n\t\t\t\t\t\t\t\tcalendar.set(Calendar.SECOND,0);\n\t\t\t\t\t\t\t\tdate=new SimpleDateFormat(\"yyyy/MM/dd hh:mm\").format(calendar.getTimeInMillis());\n\t\t\t\t\t\t\t\ttv_tiem.setText(date);\n\t\t\t\t\t\t\t}", "public void formatoTiempo() {\n String segundos, minutos, hora;\n\n hora = hrs < 10 ? String.valueOf(\"0\" + hrs) : String.valueOf(hrs);\n\n minutos = min < 10 ? String.valueOf(\"0\" + min) : String.valueOf(min);\n\n jLabel3.setText(hora + \" : \" + minutos + \" \" + tarde);\n }", "private static void updateTime(int hours, int mins) {\n String timeSet;\n if (hours > 12) {\n hours -= 12;\n timeSet = \"PM\";\n } else if (hours == 0) {\n hours += 12;\n timeSet = \"AM\";\n } else if (hours == 12)\n timeSet = \"PM\";\n else\n timeSet = \"AM\";\n\n String minutes;\n if (mins < 10)\n minutes = \"0\" + mins;\n else\n minutes = String.valueOf(mins);\n\n // Append the time to a stringBuilder\n String theTime = String.valueOf(hours) + ':' + minutes + \" \" + timeSet;\n\n // Set the timePickButton as the converted time\n timePickButton.setText(theTime);\n\n }", "public String timeFormatter(int hour, int min) {\n String minString = String.valueOf(min);\n String amOrPm = \"AM\";\n if (hour > 12) {\n hour -= 12;\n amOrPm = \"PM\";\n }\n if (minString.length() < 2) {\n minString = \"0\" + minString;\n }\n return (String.valueOf(hour) + \":\" + minString + \" \" + amOrPm);\n\n }", "Appointment(String description, String beginTime , String endTime){\n ShortDateFormat = new SimpleDateFormat(\"MM/dd/yyyy hh:mm a\", Locale.ENGLISH);\n //Check for bad data\n try{\n if(beginTime.contains(\"\\\"\")||endTime.contains(\"\\\"\"))\n throw new IllegalArgumentException(\"Date and time cannot contain quotes \");\n\n String[] tempStart = beginTime.split(\" \");\n String[] tempEnd= endTime.split(\" \");\n\n if(!tempStart[0].matches(\"(0?[1-9]|1[012])/(0?[1-9]|[12][0-9]|3[01])/((19|20)\\\\d\\\\d)\")||!tempEnd[0].matches(\"(0?[1-9]|1[012])/(0?[1-9]|[12][0-9]|3[01])/((19|20)\\\\d\\\\d)\")) {\n throw new IllegalArgumentException(\"Invalid Date Format\");\n }\n\n if(!tempStart[1].matches(\"([01]?[0-9]|2[0-3]):[0-5][0-9]\")||!tempEnd[1].matches(\"([01]?[0-9]|2[0-3]):[0-5][0-9]\"))\n throw new IllegalArgumentException(\"Time format must follow mm:hh (12 hour time)\");\n\n if(!tempStart[2].matches(\"(am|pm|AM|PM)\")&&!tempEnd[2].matches(\"(am|pm|AM|PM)\"))\n throw new IllegalArgumentException(\"Time must include am/pm\");\n }\n catch(IllegalArgumentException ex){\n System.out.println(ex.getMessage());\n System.exit(1);\n }\n\n setDate(beginTime,endTime);\n this.description = description;\n\n }", "public void generateTimes() {\n\n\t\tLocalTime currentTime = PropertiesConfig.getMorningSessionBegin();\n\t\tfor (Talk talk : morningSession.getTalks()) {\n\t\t\ttalk.setTime(currentTime);\n\t\t\tcurrentTime = currentTime.plusMinutes(talk.getLength());\n\t\t}\n\n\t\tTalk lunch = new Talk(PropertiesConfig.LUNCH_TITLE);\n\t\tlunch.setTime(PropertiesConfig.getLunchBegin());\n\t\tlunchSession.addTalk(lunch);\n\n\t\tcurrentTime = PropertiesConfig.getAfternoonSessionBegin();\n\t\tfor (Talk talk : afternoonSession.getTalks()) {\n\t\t\ttalk.setTime(currentTime);\n\t\t\tcurrentTime = currentTime.plusMinutes(talk.getLength());\n\t\t}\n\n\t\tTalk meetEvent = new Talk(PropertiesConfig.MEET_EVENT_TITLE);\n\t\tmeetEvent.setTime(currentTime);\n\t\tmeetSession.addTalk(meetEvent);\n\t}", "public void twelveHour() {\n\n //Date format 12 hour\n DateFormat twelveHour = new SimpleDateFormat(\"hh:mm aa\", Locale.ENGLISH);\n\n setTimeZone();\n\n Calendar s = Calendar.getInstance(sydney);\n twelveHour.setTimeZone(sydney);\n\n String timeS = twelveHour.format(s.getTime());\n sydneyTime = findViewById(R.id.sydneytime);\n sydneyTime.setText(timeS);\n\n Calendar t = Calendar.getInstance(tokyo);\n twelveHour.setTimeZone(tokyo);\n\n String timeT = twelveHour.format(t.getTime());\n tokyoTime = findViewById(R.id.tokyotime);\n tokyoTime.setText(timeT);\n\n Calendar a = Calendar.getInstance(auckland);\n twelveHour.setTimeZone(auckland);\n\n String timeA = twelveHour.format(a.getTime());\n aucklandTime = findViewById(R.id.aucklandtime);\n aucklandTime.setText(timeA);\n\n Calendar d = Calendar.getInstance(dubai);\n twelveHour.setTimeZone(dubai);\n\n String timeD = twelveHour.format(d.getTime());\n dubaiTime = findViewById(R.id.dubaitime);\n dubaiTime.setText(timeD);\n\n Calendar n = Calendar.getInstance(newyork);\n twelveHour.setTimeZone(newyork);\n\n String timeN = twelveHour.format(n.getTime());\n newyorkTime = findViewById(R.id.newyorktime);\n newyorkTime.setText(timeN);\n }", "public DayHourGreeting () {\n Calendar c = Calendar.getInstance();\n int hourOfDay = c.get(Calendar.HOUR_OF_DAY);\n setGreeting(hourOfDay);\n }", "public String retornaHora(){\n\t\tCalendar calendar = new GregorianCalendar();\n\t\tSimpleDateFormat hora = new SimpleDateFormat(\"HH\");\n\t\tSimpleDateFormat minuto = new SimpleDateFormat(\"mm\");\n\t\tDate date = new Date();\n\t\tcalendar.setTime(date);\n\t\treturn hora.format(calendar.getTime()) + \"h\" + minuto.format(calendar.getTime());\n\t}", "public String toString () {\n String dayTime;\n\n if (isPM == true)\n dayTime = \"PM\";\n\n else\n dayTime = \"AM\";\n\n String hourString = String.format(\"%02d\", hour);\n String minString = String.format(\"%02d\", minute);\n return (hourString + \":\" + minString + \" \" + dayTime);\n }", "private void setTimeDate(){\n tvTime = (TextView) findViewById(R.id.tv_time);\n dateFormat = new SimpleDateFormat(\"hh:mm a\");\n tvTime.setText(dateFormat.format(new Date()).toString());\n\n //Set Date to Top TextView\n tvDate = (TextView) findViewById(R.id.tv_date);\n dateFormat = new SimpleDateFormat(\"EEE, MMM d\");\n tvDate.setText(dateFormat.format(new Date()).toString());\n }", "private void timeInitializer(View view){\n currentDate = view.findViewById(R.id.schedule_textView_currentDate);\n GregorianCalendar now = new GregorianCalendar();\n DateFormat df= DateFormat.getDateInstance(DateFormat.SHORT);\n currentDate.setText(df.format(now.getTime()));\n\n currentWeek=view.findViewById(R.id.calendar_week_switch);\n Calendar c = Calendar.getInstance();\n c.setTime(new Date());\n int num_week = c.get(Calendar.WEEK_OF_YEAR);\n if(num_week%2==0){\n currentWeek.setText(R.string.even);\n isEven=true;\n }\n else{\n currentWeek.setText(R.string.odd);\n isEven=false;\n }\n\n }", "private static String timeLine()\n {\n return String.format(STR_FORMAT_1 + STR_FORMAT_2, TIME_STR, TIME);\n }", "private String formatTime(String dateObject){\n\n SimpleDateFormat input = new SimpleDateFormat(\"yyyy-MM-dd'T'HH:mm:ss'Z'\"); // format kita \"HARUS SAMA TIDAK BOLEH FORMATNYA BEDA BAHKAN 1 CHAR PUN\n SimpleDateFormat output= new SimpleDateFormat(\"h:mm a\");\n Date jam = null;\n try {\n jam = input.parse(dateObject);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n return output.format(jam);\n }", "public String getTimeString() {\n int hour = date.get(Calendar.HOUR);\n int minute = date.get(Calendar.MINUTE);\n\n String AM_PM = \"PM\";\n if (date.get(Calendar.AM_PM) == Calendar.AM) AM_PM = \"AM\";\n\n String hour_fixed = String.valueOf(hour);\n if (hour == 0) hour_fixed = \"12\";\n\n String minute_fixed = String.valueOf(minute);\n while (minute_fixed.length() < 2) {\n minute_fixed = \"0\" + minute_fixed;\n }\n\n return hour_fixed + \":\" + minute_fixed + ' ' + AM_PM;\n }", "@SuppressLint(\"SetTextI18n\")\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n int hourFinal = hourOfDay;\n\n String format;\n String sHour;\n if(hourFinal >12)\n {\n hourFinal -=12;\n format = \" PM\";\n }else if(hourFinal ==0)\n {\n hourFinal = 12;\n format = \" AM\";\n }else if(hourFinal ==12)\n format = \" PM\";\n else\n format = \" AM\";\n\n sHour = String.valueOf(hourFinal);\n\n if(hourFinal <10)\n sHour = \"0\"+String.valueOf(hourFinal);\n\n if(minute<10)\n fTime.setText(sHour+\" : 0\"+String.valueOf(minute)+format);\n else\n fTime.setText(sHour+\" : \"+String.valueOf(minute)+format);\n }", "private String getDate() {\n\t\tSimpleDateFormat parseFormat = new SimpleDateFormat(\"hh:mm a\");\n\t\tDate date = new Date();\n\t\tString s = parseFormat.format(date);\n\t\treturn s;\n\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog42 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t42Hour42 = hourOfDay1;\n t42Minute42 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t42Hour42, t42Minute42);\n //set selected time on text view\n\n\n timeE21 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime21.setText(timeE21);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog42.updateTime(t42Hour42, t42Minute42);\n //show dialog\n timePickerDialog42.show();\n }", "private void updateDateAndTimeTextView(Calendar instance) {\n\t\tmCalendar = instance;\n\n\t\t// update the dateText view with the corresponding date\n\t\tbtUpdateDateAndHour.setText(android.text.format.DateFormat\n\t\t\t\t.getDateFormat(this).format(mCalendar.getTime())\n\t\t\t\t+ \" \"\n\t\t\t\t+ functions.getTimeFromDate(mCalendar.getTime()));\n\t}", "@Override\n public void actionPerformed(ActionEvent e) {\n Date date = new Date();\n DateFormat timeFormat = new SimpleDateFormat(\"HH:mm:ss\");\n String time = timeFormat.format(date);\n relogio.setText(time);\n \n Date date2 = new Date();\n DateFormat timeFormat2 = new SimpleDateFormat(\"dd/MM/yyyy\");\n String time2 = timeFormat2.format(date2);\n data.setText(time2);\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog36 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t36Hour36 = hourOfDay1;\n t36Minute36 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t36Hour36, t36Minute36);\n //set selected time on text view\n\n\n timeE18 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime18.setText(timeE18);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog36.updateTime(t36Hour36, t36Minute36);\n //show dialog\n timePickerDialog36.show();\n }", "public String toString()\r\n {\r\n DecimalFormat twoDigits = new DecimalFormat( \"00\" );\r\n\r\n return ( this.getHour() == 12 || this.getHour() == 0 ?\r\n 12 : this.getHour() % 12 ) + \":\" +\r\n twoDigits.format( this.getMinute() ) + \":\" +\r\n twoDigits.format( this.getSecond() ) +\r\n ( this.getHour() < 12 ? \" AM\" : \" PM\" );\r\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog45 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t45Hour45 = hourOfDay1;\n t45Minute45 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t45Hour45, t45Minute45);\n //set selected time on text view\n\n\n timeS23 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime23.setText(timeS23);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog45.updateTime(t45Hour45, t45Minute45);\n //show dialog\n timePickerDialog45.show();\n }", "@Override\n public void onTimeSet(TimePicker timePicker, int hour, int minutes) {\n\n final String selectedDate = String.format(\"%02d\", hour) + \":\" +String.format(\"%02d\", minutes);\n mTimeSession.setText(selectedDate);\n timeFormatted=String.format(\"%02d\", hour)+\"\"+String.format(\"%02d\", minutes);\n }" ]
[ "0.6262512", "0.6246306", "0.61734056", "0.6106533", "0.6104968", "0.60769886", "0.60651135", "0.6037279", "0.6026983", "0.60211575", "0.6017589", "0.6011155", "0.6007749", "0.6000879", "0.59941685", "0.59915626", "0.5990557", "0.59806716", "0.5978301", "0.59715825", "0.5966566", "0.59665596", "0.59624285", "0.59572273", "0.5954252", "0.59480095", "0.5942352", "0.594173", "0.5940547", "0.59362096", "0.59304225", "0.5928153", "0.59261024", "0.5925694", "0.59231263", "0.5914471", "0.59122723", "0.59096414", "0.5906023", "0.59057623", "0.59026873", "0.5895656", "0.58951586", "0.5881023", "0.58806705", "0.58783495", "0.58769196", "0.5873524", "0.5870715", "0.5868316", "0.5863815", "0.5861293", "0.58583754", "0.5854725", "0.5853083", "0.58499265", "0.5844696", "0.58323264", "0.5829326", "0.5826727", "0.5819405", "0.58129925", "0.5810354", "0.5810335", "0.58004415", "0.5795522", "0.57952327", "0.579386", "0.5788948", "0.5773827", "0.5763758", "0.5750357", "0.5743343", "0.5742808", "0.57268184", "0.5726718", "0.57235515", "0.57222706", "0.5700155", "0.5690664", "0.56896234", "0.56834453", "0.56818813", "0.5679656", "0.5668733", "0.5664752", "0.56610024", "0.56504524", "0.56484187", "0.5620689", "0.55947983", "0.5586994", "0.5583618", "0.5580684", "0.55803514", "0.55794275", "0.5574188", "0.55695784", "0.5566001", "0.5562935" ]
0.5996904
14
Opens a dialog to choose the date with predefined date values (the current ones).
private void chooseDateDialog() { Calendar c = Calendar.getInstance(); int year = c.get(Calendar.YEAR); int month = c.get(Calendar.MONTH); int day = c.get(Calendar.DATE); DatePickerDialog datePickerDialog = new DatePickerDialog(Objects.requireNonNull(getContext()), this, year, month, day); datePickerDialog.show(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void onClick(View v) {\n new DatePickerDialog(MainActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(MainActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "public void selectDate(){\r\n\t\tcloseDateText.sendKeys(ConvertDate());\r\n\t}", "private void showDateDialog() {\n\t\tDateDetailInfo[] dateInfo = DateDetailInfo.getDateDetailInfo();\n\t\tboolean noDate = (dateInfo == null);\n\t\tboolean allPermanent = (null != dateInfo)\n\t\t\t\t&& (dateInfo.length == 1)\n\t\t\t\t&& (dateInfo[0] != null)\n\t\t\t\t&& (dateInfo[0].deadText != null)\n\t\t\t\t&& (dateInfo[0].deadText.equals(this.getResources().getString(\n\t\t\t\t\t\tR.string.package_detail_forever)));\n\t\tif (DateDetailInfo.dayOffMax > 0 && (!(noDate || allPermanent))) {\n\t\t\tinitDateDialog();\n\t\t\tDateDialog dialog = new DateDialog(this);\n\t\t\tdialog.getWindow().setBackgroundDrawable(new ColorDrawable(0));\n\t\t\tdialog.requestWindowFeature(Window.FEATURE_NO_TITLE);\n\t\t\tdialog.setListener(new DialogInterface.OnClickListener() {\n\t\t\t\t@Override\n\t\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\t\tstartGetTicketActivity();\n\t\t\t\t}\n\t\t\t});\n\t\t\tif (null != DateDialog.mListStr && DateDialog.mListStr.length > 1) {\n\t\t\t\tdialog.show();\n\t\t\t}\n\t\t}\n\t}", "public void selectDate()\r\n\t{\r\n\t\tsetLayout(new FlowLayout());\r\n\t\t\r\n\t\t// Create the DatePicker\r\n\t\tUtilDateModel model = new UtilDateModel();\r\n\t\tProperties properties = new Properties();\r\n\t\tproperties.put(\"text.today\", \"Today\");\r\n\t\tproperties.put(\"text.month\", \"Month\");\r\n\t\tproperties.put(\"text.year\", \"Year\");\r\n\t\tJDatePanelImpl datePanel = new JDatePanelImpl(model,properties);\r\n\t\tdatePicker = new JDatePickerImpl(datePanel, new DateFormatter());\r\n\t\t\r\n\t\t// Add confirmation button\r\n\t\tbutton = new JButton(\"OK\");\r\n\t\tbutton.addActionListener(this);\r\n\t\t\r\n\t\t// Display the DatePicker\r\n\t\tadd(datePicker);\r\n\t\tadd(button);\r\n setSize(300,300);\r\n setLocationRelativeTo(null);\r\n setVisible(true);\r\n\t}", "private void showDateDialog(){\n\t\tDatePickerDialog dpd = new DatePickerDialog(this, new OnDateSetListener(){\r\n\t\t\tpublic void onDateSet(DatePicker view , int year, int month, int day){\r\n\t\t\t\tgiorno.set(year,month,day);\r\n\t\t\t\tEditText et_giorno = (EditText) BookingActivity.this.findViewById(R.id.prenotazione_et_giorno);\r\n\t\t\t\tformatter.applyPattern(\"dd MMMMM yyyy\");\r\n\t\t\t\tet_giorno.setText(formatter.format(giorno.getTime()));\r\n\t\t\t}\t\t\t \t\r\n\t\t}, giorno.get(Calendar.YEAR), giorno.get(Calendar.MONTH), giorno.get(Calendar.DAY_OF_MONTH));\r\n\t\tdpd.show();\r\n\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), startdatepicker, trigger.getStarttime().get(Calendar.YEAR), trigger.getStarttime().get(Calendar.MONTH), trigger.getStarttime().get(Calendar.DAY_OF_MONTH)).show();\n }", "public void openDatePicker() {\n\n Calendar now = Calendar.getInstance();\n DatePickerDialog dpd = DatePickerDialog.newInstance(\n this,\n now.get(Calendar.YEAR),\n now.get(Calendar.MONTH),\n now.get(Calendar.DAY_OF_MONTH)\n );\n dpd.show(getActivity().getFragmentManager(), StringConstants.KEY_DATEPICKER_DIALOG);\n //dpd.setAccentColor(R.color.hb_medication_history);\n dpd.showYearPickerFirst(true);\n dpd.setMaxDate(now);\n dpd.setYearRange(StaticConstants.MIN_DATE, now.get(Calendar.YEAR));\n }", "@Override\n\t\t\tpublic void onClick(View arg0) {\n\t\t\t\tshowDialog(SET_DATE_DIALOG);\n\n\t\t\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(select_time_date.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n\n new DatePickerDialog(CompoffActivity.this, date, currentDate\n .get(Calendar.YEAR), currentDate.get(Calendar.MONTH),\n currentDate.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void selectDate() {\n Calendar calendar = Calendar.getInstance();\n int year = calendar.get(Calendar.YEAR);\n int month = calendar.get(Calendar.MONTH);\n int day = calendar.get(Calendar.DAY_OF_MONTH);\n DatePickerDialog datePickerDialog = new DatePickerDialog(this, new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(DatePicker datePicker, int year, int month, int day) {\n mDatebtn.setText(day + \"-\" + (month + 1) + \"-\" + year); //sets the selected date as test for button\n }\n }, year, month, day);\n datePickerDialog.show();\n }", "private void DateSelection(final TextView tv_inv_date) {\n try {\r\n AlertDialog.Builder dlgReportDate = new AlertDialog.Builder(myContext);\r\n final DatePicker dateReportDate = new DatePicker(myContext);\r\n String date_str = tvDate.getText().toString();\r\n String dd = date_str.substring(6,10)+\"-\"+date_str.substring(3,5)+\"-\"+date_str.substring(0,2);\r\n DateTime objDate = new DateTime(dd);\r\n dateReportDate.updateDate(objDate.getYear(), objDate.getMonth(), objDate.getDay());\r\n String strMessage = \"\";\r\n\r\n\r\n\r\n dlgReportDate\r\n .setIcon(R.drawable.ic_launcher)\r\n .setTitle(\"Date Selection\")\r\n .setMessage(strMessage)\r\n .setView(dateReportDate)\r\n .setPositiveButton(\"OK\", new DialogInterface.OnClickListener() {\r\n String strDd = \"\";\r\n public void onClick(DialogInterface dialog, int which) {\r\n if (dateReportDate.getDayOfMonth() < 10) {\r\n strDd = \"0\" + String.valueOf(dateReportDate.getDayOfMonth())+\"-\";\r\n } else {\r\n strDd = String.valueOf(dateReportDate.getDayOfMonth())+\"-\";\r\n }\r\n if (dateReportDate.getMonth() < 9) {\r\n strDd += \"0\" + String.valueOf(dateReportDate.getMonth() + 1) + \"-\";\r\n } else {\r\n strDd += String.valueOf(dateReportDate.getMonth() + 1) + \"-\";\r\n }\r\n\r\n strDd += String.valueOf(dateReportDate.getYear());\r\n tv_inv_date.setText(strDd);\r\n Log.d(\"ReprintDate\", \"Selected Date:\" + strDd);\r\n }\r\n })\r\n .setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\r\n\r\n public void onClick(DialogInterface dialog, int which) {\r\n // TODO Auto-generated method stub\r\n\r\n }\r\n })\r\n .show();\r\n } catch (Exception e) {\r\n e.printStackTrace();\r\n }\r\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(context, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getContext(), date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getContext(), date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\r\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tshowDialog(DATE_DIALOG_ID);\r\n\t\t\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(merchantHome, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void showDateDialog(){\n final Calendar newCalendar = Calendar.getInstance();\n\n /**\n * Initiate DatePicker dialog\n */\n datePickerDialog = new DatePickerDialog(this, new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n /**\n * Method ini dipanggil saat kita selesai memilih tanggal di DatePicker\n */\n\n /**\n * Set Calendar untuk menampung tanggal yang dipilih\n */\n Calendar newDate = Calendar.getInstance();\n newDate.set(year, monthOfYear, dayOfMonth);\n\n\n if(!newDate.before(newCalendar)){\n /**\n * Update TextView with choosen date\n */\n newDate.set(Calendar.HOUR_OF_DAY, 0);\n newDate.set(Calendar.MINUTE, 0);\n newDate.set(Calendar.SECOND, 0);\n newDate.set(Calendar.MILLISECOND,0);\n mDateTextView.setTextColor(Color.BLACK);\n String day = mDateFormatter.getDayName(newDate.getTime());\n String date = mDateFormatter.getOnlyDate(newDate.getTime());\n String month = mDateFormatter.getMonth(newDate.getTime());\n mDateTextView.setText(day + \" \" + date + \",\" + month);\n mChoosenSaveDate = newDate;\n }else{\n mDateTextView.setText(\"Deadline has to be at leats same as current date\");\n mDateTextView.setTextColor(Color.RED);\n Toast.makeText(view.getContext(),\"invalid choosen date\",\n Toast.LENGTH_LONG).show();\n }\n\n\n }\n\n },newCalendar.get(Calendar.YEAR), newCalendar.get(Calendar.MONTH), newCalendar.get(Calendar.DAY_OF_MONTH));\n\n /**\n * Tampilkan DatePicker dialog\n */\n datePickerDialog.show();\n\n }", "public void onPickDateButtonClick(View v){\n\t\tDialogFragment newFragment = new DatePickerFragment();\n\t\t\n\t\tlong milis = -1;\t\t\n\t\tif (mGameSettings.contains(Constants.GAME_PREFERENCES_DOB)) {\n\t\t\tmilis = mGameSettings.getLong(Constants.GAME_PREFERENCES_DOB, 0);\n\t\t}\n\t\t\n\t\tBundle parametros = new Bundle();\n\t\tparametros.putLong(\"date\", milis); \n\t\t\n\t\tnewFragment.setArguments(parametros);\t\n\t\t\n\t\t\n\t\tnewFragment.show(getSupportFragmentManager(), \"datePicker\");\n\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getContext(), date2, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void DateSelection(final TextView tv_inv_date ) {\n try {\n AlertDialog.Builder dlgReportDate = new AlertDialog.Builder(this);\n final DatePicker dateReportDate = new DatePicker(this);\n String date_str = tvDate.getText().toString();\n String dd = date_str.substring(6,10)+\"-\"+date_str.substring(3,5)+\"-\"+date_str.substring(0,2);\n DateTime objDate = new DateTime(dd);\n dateReportDate.updateDate(objDate.getYear(), objDate.getMonth(), objDate.getDay());\n String strMessage = \"\";\n\n\n dlgReportDate\n .setIcon(R.drawable.ic_launcher)\n .setTitle(\"Date Selection\")\n .setMessage(strMessage)\n .setView(dateReportDate)\n .setPositiveButton(\"OK\", new DialogInterface.OnClickListener() {\n String strDd = \"\";\n public void onClick(DialogInterface dialog, int which) {\n if (dateReportDate.getDayOfMonth() < 10) {\n strDd = \"0\" + String.valueOf(dateReportDate.getDayOfMonth())+\"-\";\n } else {\n strDd = String.valueOf(dateReportDate.getDayOfMonth())+\"-\";\n }\n if (dateReportDate.getMonth() < 9) {\n strDd += \"0\" + String.valueOf(dateReportDate.getMonth() + 1) + \"-\";\n } else {\n strDd += String.valueOf(dateReportDate.getMonth() + 1) + \"-\";\n }\n\n strDd += String.valueOf(dateReportDate.getYear());\n tv_inv_date.setText(strDd);\n Log.d(\"ReprintDate\", \"Selected Date:\" + strDd);\n }\n })\n .setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\n\n public void onClick(DialogInterface dialog, int which) {\n // TODO Auto-generated method stub\n\n }\n })\n .show();\n } catch (Exception e) {\n e.printStackTrace();\n }\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(SearchTripActivity.this, dated, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void initPopupDate() {\n editDate = findViewById(R.id.date_depense);\n date = new DatePickerDialog.OnDateSetListener() {\n\n public void onDateSet(DatePicker view, int year, int monthOfYear,\n int dayOfMonth) {\n // TODO Auto-generated method stub\n myCalendar.set(Calendar.YEAR, year);\n myCalendar.set(Calendar.MONTH, monthOfYear);\n myCalendar.set(Calendar.DAY_OF_MONTH, dayOfMonth);\n updateDate();\n }\n\n };\n\n // onclick - popup datepicker\n editDate.setOnClickListener(new View.OnClickListener() {\n\n @Override\n public void onClick(View v) {\n // TODO Auto-generated method stub\n new DatePickerDialog(context, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }\n });\n }", "public void setDate() {\n DatePickerDialog dateDialog = new DatePickerDialog(this, myDateListener,\n calendar.get(Calendar.YEAR), calendar.get(Calendar.MONTH), calendar.get(Calendar.DATE));\n //set the date limits so user cannot pick a date outside of game scope\n dateDialog.getDatePicker().setMinDate(System.currentTimeMillis() + MILLIS_IN_DAY);\n dateDialog.getDatePicker().setMaxDate(System.currentTimeMillis() + (MILLIS_IN_DAY * MAX_END_DAY_COUNT));\n dateDialog.show();\n }", "public Date getSelectedDate();", "@Override\n public void onClick(View v) {\n new DatePickerDialog(Edit_Profile.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(SearchTripActivity.this, datea, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tnew DatePickerDialog(getActivity(), date, myCalendar\n\t\t\t\t\t\t.get( Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n\t\t\t\t\t\tmyCalendar.get(Calendar.DAY_OF_MONTH)).show();\n\t\t\t}", "@Override\n\t\t\t\tpublic void onClick(View v) {\n\t\t\t\t\tString fcraDate = (String) btnFcraDate.getText();\n\t\t\t\t\tString dateParts[] = fcraDate.split(\"-\");\n\t\t\t\t\tsetfromday1 = dateParts[0];\n\t\t\t\t\tsetfrommonth1 = dateParts[1];\n\t\t\t\t\tsetfromyear1 = dateParts[2];\n\t \n\t\t\t\t\t//System.out.println(\"fcradate is:\"+setfromday1);\n\t\t\t\t\t//System.out.println(\"fcradate is:\"+setfrommonth1);\n\t\t\t\t\t//System.out.println(\"fcradate is:\"+setfromyear1);\n\t\t\t\t\t//System.out.println(\"fcradate is:\"+fcraDate);\n\t\t\t\t\tshowDialog(FCRA_DATE_DIALOG_ID);\n\t\t\t\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(AddVehicleActivity.this, date2, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(DatePickerActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(Edit_Profile.this, dateannier, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(AddTripActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(CSVActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(CSVActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View view) {\n new DatePickerDialog(AddEventActivity.this, start_Journey_Date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "public void selectDateToMeet(View view) {\n int day;\n int month;\n int year;\n\n /* if the date button has tag of DATE_PICKED then set the date on dialog to date picked earlier,\n otherwise display todays date on the dialog */\n if (dateText.getText().toString().equals(\"\") || !dateText.getText().toString().toLowerCase().contains(\"date\")) {\n String dates[] = dateText.getText().toString().split(\"-\");\n\n day = Integer.parseInt(dates[2]);\n //minus 1 to get the month index\n month = Integer.parseInt(dates[1]) - 1;\n year = Integer.parseInt(dates[0]);\n\n } else {\n //get todays date\n Calendar cal = Calendar.getInstance();\n\n day = cal.get(Calendar.DAY_OF_MONTH);\n month = cal.get(Calendar.MONTH);\n year = cal.get(Calendar.YEAR);\n }\n\n //set the dialog with the date and show it\n DatePickerDialog dialog = new DatePickerDialog(BookPlanActivity.this,\n android.R.style.Theme_Holo_Light_Dialog_MinWidth,\n mDataSetListener, year, month, day);\n\n dialog.setButton(DialogInterface.BUTTON_NEUTRAL, \"Clear Date\", new DialogInterface.OnClickListener() {\n @Override\n public void onClick(DialogInterface dialog, int which) {\n dialog.dismiss();\n dateText.setText(\"Select a date\");\n }\n });\n\n dialog.getWindow().setBackgroundDrawable(new ColorDrawable(Color.TRANSPARENT));\n dialog.show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(AddVehicleActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), enddatepicker, trigger.getEndtime().get(Calendar.YEAR), trigger.getEndtime().get(Calendar.MONTH), trigger.getEndtime().get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(RegistrationActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(UserUpdate.this, date, cal\n .get(Calendar.YEAR), cal.get(Calendar.MONTH), cal\n .get(Calendar.DAY_OF_MONTH)).show();\n }", "public void promptDate(String date)\n {\n this.date = date;\n }", "@Override\n public void onClick(View view) {\n new DatePickerDialog(AddEventActivity.this, end_Journey_Date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void chooseDateFromCalendar(Button dateButton){\n DateFormat sdf = new SimpleDateFormat(\"dd/MM/yyyy\");\n Calendar nowCalendar = formatCalendar(Calendar.getInstance());\n\n DatePickerDialog datePickerDialog = new DatePickerDialog(getContext(),\n R.style.Theme_TrainClimbing_DatePicker,\n (v, y, m, d) -> {\n inputCalendar.set(y, m, d);\n if (inputCalendar.after(nowCalendar))\n dateButton.setText(R.string.ad_button_date);\n else\n dateButton.setText(sdf.format(inputCalendar.getTime()));\n }, inputCalendar.get(Calendar.YEAR),\n inputCalendar.get(Calendar.MONTH),\n inputCalendar.get(Calendar.DAY_OF_MONTH));\n\n datePickerDialog.getDatePicker().setFirstDayOfWeek(Calendar.MONDAY);\n datePickerDialog.getDatePicker().setMinDate(formatCalendar(\n new GregorianCalendar(2000, 7, 19)).getTimeInMillis());\n datePickerDialog.getDatePicker().setMaxDate(nowCalendar.getTimeInMillis());\n datePickerDialog.show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(NameLoginActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(AddActivity.this, date, myCalendar.get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "public void onClick(DialogInterface dialog, int item) {\n switch (item) {\n case 0://Date Modifier\n LayoutInflater ld = LayoutInflater.from(GoalDisActivity.this);\n promptsDateView = ld.inflate(R.layout.date_button, null);//promptsDateView declared global for later reference to DateDialogButton\n build = new AlertDialog.Builder(GoalDisActivity.this);\n build.setTitle(\"Goal-Date\");\n build.setMessage(\"Please Enter new Goal Date\");\n build.setView(promptsDateView);\n newDate = (Button) promptsDateView.findViewById(R.id.newGoalDate);\n newDate.setOnClickListener(new View.OnClickListener() {\n\n @Override\n public void onClick(View view) {\n showDialog(DATE_DIALOG_ID);\n }\n });\n\n final Calendar c = Calendar.getInstance();\n currentYear = c.get(Calendar.YEAR);\n currentMonth = c.get(Calendar.MONTH);\n currentDay = c.get(Calendar.DAY_OF_MONTH);\n\n newDate.setFocusableInTouchMode(true);\n //newDate.setFocusable(true);\n //newDate.requestFocus();\n build.setPositiveButton(\"Ok\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n dataBase = gHelper.getWritableDatabase();\n Cursor mCursor = dataBase.rawQuery(\"SELECT * FROM \" + DbHelperGoal.TABLE_NAME + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2), null);\n if (mCursor.moveToFirst()) {\n do {\n dayValue = mCursor.getString(mCursor.getColumnIndex(DbHelperGoal.DAY));\n } while (mCursor.moveToNext());\n }\n\n // checks if user has chosen the date or not, if chosen, executes If condition\n if (dayG != null && !dayG.isEmpty() && monthG != null && !monthG.isEmpty() && yearG != null && !yearG.isEmpty()) {\n int dayVal = Integer.valueOf(dayG), monthVal = Integer.valueOf(monthG), yearVal = Integer.valueOf(yearG);\n String strSQL = \"UPDATE \" + DbHelperGoal.TABLE_NAME + \" SET \" + DbHelperGoal.DAY + \"=\" + String.valueOf(dayVal) + \", \" + DbHelperGoal.MONTH + \"=\" + String.valueOf(monthVal) + \", \" + DbHelperGoal.YEAR + \"=\" + String.valueOf(yearVal) + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2);\n dataBase.execSQL(strSQL);\n Toast.makeText(getApplication(), dayValue.toString(), Toast.LENGTH_SHORT).show();\n //PayValue.setText(\"\");\n displayData();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n\n } else {// if user has not chosen but clicked on \"Ok\", then execute 'else'\n displayData();\n Toast.makeText(getApplication(), \"Please select a date\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n build.setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n Toast.makeText(getApplication(), \"New Date Cancelled\", Toast.LENGTH_SHORT).show();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n }\n });\n alert = build.create();\n alert.show();\n alert.getWindow().setSoftInputMode(WindowManager.LayoutParams.SOFT_INPUT_STATE_ALWAYS_VISIBLE);\n break;\n case 1://Payment\n LayoutInflater li = LayoutInflater.from(GoalDisActivity.this);\n View promptsPaymentView = li.inflate(R.layout.payment_layout, null);\n build = new AlertDialog.Builder(GoalDisActivity.this);\n build.setTitle(\"Payment\");\n build.setMessage(\"Please Enter payment amount\");\n build.setView(promptsPaymentView);\n PayValue = (EditText) promptsPaymentView.findViewById(R.id.PaymentEnter1);\n //PayValue.isFocused();\n PayValue.setFocusableInTouchMode(true);\n PayValue.setFocusable(true);\n PayValue.requestFocus();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.showSoftInput(PayValue, InputMethodManager.SHOW_IMPLICIT);\n build.setPositiveButton(\"Ok\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n check = 0;\n val = 0;\n dataBase = gHelper.getWritableDatabase();\n Cursor mCursor = dataBase.rawQuery(\"SELECT * FROM \" + DbHelperGoal.TABLE_NAME + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2), null);\n if (mCursor.moveToFirst()) {\n do {\n moneyValue = mCursor.getString(mCursor.getColumnIndex(DbHelperGoal.ALT_PAYMENT));\n dbExpAmount = mCursor.getString(mCursor.getColumnIndex(DbHelperGoal.AMOUNT));\n check = mCursor.getFloat(mCursor.getColumnIndex(DbHelperGoal.ALT_EXPENSE));\n } while (mCursor.moveToNext());\n }\n val = Float.valueOf(PayValue.getText().toString()) + Float.valueOf(moneyValue);\n if (val - check <= Float.valueOf(dbExpAmount) && val - check >= 0) {// within the Target Amount\n String strSQL = \"UPDATE \" + DbHelperGoal.TABLE_NAME + \" SET \" + DbHelperGoal.ALT_PAYMENT + \"=\" + String.valueOf(val) + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2);\n dataBase.execSQL(strSQL);\n Toast.makeText(getApplication(), PayValue.getText().toString(), Toast.LENGTH_SHORT).show();\n //PayValue.setText(\"\");\n displayData();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n } else if (val - check > Float.valueOf(dbExpAmount) && val - check >= 0) {// if client collects extra amount for that goal, the Target amount extends\n build2 = new AlertDialog.Builder(GoalDisActivity.this);\n build2.setTitle(\"Confirmation\");\n build2.setMessage(\"The Payment Amount is exceeding the Target Amount. Do you want to increment the Target amount to the new value?\");\n build2.setPositiveButton(\"Yes\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n String strSQL = \"UPDATE \" + DbHelperGoal.TABLE_NAME + \" SET \" + DbHelperGoal.AMOUNT + \"=\" + String.valueOf(val - check) + \",\" + DbHelperGoal.ALT_PAYMENT + \"=\" + String.valueOf(val) + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2);\n dataBase.execSQL(strSQL);\n Toast.makeText(getApplication(), PayValue.getText().toString(), Toast.LENGTH_SHORT).show();\n //PayValue.setText(\"\");\n displayData();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n }\n });\n build2.setNeutralButton(\"No, Only Savings\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n\n\n String strSQL = \"UPDATE \" + DbHelperGoal.TABLE_NAME + \" SET \" + DbHelperGoal.ALT_PAYMENT + \"=\" + String.valueOf(val) + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2);\n dataBase.execSQL(strSQL);\n Toast.makeText(getApplication(), PayValue.getText().toString(), Toast.LENGTH_SHORT).show();\n //PayValue.setText(\"\");\n displayData();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n }\n });\n\n build2.setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n Toast.makeText(getApplication(), \"Payment Cancelled\", Toast.LENGTH_SHORT).show();\n //displayData();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n }\n });\n\n alert2 = build2.create();\n alert2.show();\n alert2.getWindow().setSoftInputMode(WindowManager.LayoutParams.SOFT_INPUT_STATE_ALWAYS_VISIBLE);\n\n } else {\n Toast.makeText(getApplication(), \"Sorry, the amount is beyond the Target Amount\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n build.setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n Toast.makeText(getApplication(), \"Payment Cancelled\", Toast.LENGTH_SHORT).show();\n //InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n //imm.hideSoftInputFromWindow(PayValue.getWindowToken(), 0);\n dialog.cancel();\n }\n });\n alert = build.create();\n alert.show();\n alert.getWindow().setSoftInputMode(WindowManager.LayoutParams.SOFT_INPUT_STATE_ALWAYS_VISIBLE);\n break;\n case 2://Expense\n //Toast.makeText(getApplication(), \"Expense\", Toast.LENGTH_SHORT).show();\n LayoutInflater le = LayoutInflater.from(GoalDisActivity.this);\n View promptsExpenseView = le.inflate(R.layout.payment_layout, null);\n build = new AlertDialog.Builder(GoalDisActivity.this);\n build.setTitle(\"Expense\");\n build.setMessage(\"Please Enter withdrawl amount\");\n build.setView(promptsExpenseView);\n ExpValue = (EditText) promptsExpenseView.findViewById(R.id.PaymentEnter1);\n //PayValue.isFocused();\n build.setPositiveButton(\"Ok\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n check = 0;\n val = 0;\n dataBase = gHelper.getWritableDatabase();\n Cursor mCursor = dataBase.rawQuery(\"SELECT * FROM \" + DbHelperGoal.TABLE_NAME + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2), null);\n if (mCursor.moveToFirst()) {\n do {\n moneyValue = mCursor.getString(mCursor.getColumnIndex(DbHelperGoal.ALT_EXPENSE));\n dbExpAmount = mCursor.getString(mCursor.getColumnIndex(DbHelperGoal.AMOUNT));\n check = mCursor.getFloat(mCursor.getColumnIndex(DbHelperGoal.ALT_PAYMENT));\n } while (mCursor.moveToNext());\n }\n\n val = Float.valueOf(ExpValue.getText().toString()) + Float.valueOf(moneyValue);// TextBox + db value\n if (check - val <= Float.valueOf(dbExpAmount) && check - val >= 0) {\n String strSQL = \"UPDATE \" + DbHelperGoal.TABLE_NAME + \" SET \" + DbHelperGoal.ALT_EXPENSE + \"=\" + String.valueOf(val) + \" WHERE \" + DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2);\n dataBase.execSQL(strSQL);\n ExpValue.setText(\"\");\n displayData();\n dialog.cancel();\n } else {\n Toast.makeText(getApplication(), \"Exceeding the Target amount limit.\", Toast.LENGTH_LONG).show();\n }\n }\n });\n build.setNegativeButton(\"Cancel\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n Toast.makeText(getApplication(), \"Expense Cancelled\", Toast.LENGTH_SHORT).show();\n dialog.cancel();\n }\n });\n alert = build.create();\n alert.show();\n alert.getWindow().setSoftInputMode(WindowManager.LayoutParams.SOFT_INPUT_STATE_ALWAYS_VISIBLE);\n break;\n case 3://Delete Data\n //Toast.makeText(getApplication(),\"Delete\",Toast.LENGTH_SHORT).show();\n build = new AlertDialog.Builder(GoalDisActivity.this);\n build.setTitle(\"Delete \" + goalTitle.get(arg2) + \" \" + date.get(arg2) + \" \" + amount.get(arg2));\n build.setMessage(\"Do you want to delete ?\");\n build.setPositiveButton(\"Yes\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n Toast.makeText(getApplicationContext(), goalTitle.get(arg2) + \" \" + date.get(arg2) + \" \" + amount.get(arg2) + \" is deleted.\", Toast.LENGTH_LONG).show();\n dataBase.delete(DbHelperGoal.TABLE_NAME, DbHelperGoal.KEY_ID + \"=\" + keyId.get(arg2), null);\n displayData();\n dialog.cancel();\n }\n });\n build.setNegativeButton(\"No\", new DialogInterface.OnClickListener() {\n public void onClick(DialogInterface dialog, int which) {\n dialog.cancel();\n }\n });\n //AlertDialog alert = build.create();\n alert = build.create();\n alert.show();\n break;\n default:\n Toast.makeText(getApplication(), \"default\", Toast.LENGTH_SHORT).show();\n }\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(RegisterActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "public void initializeDate() {\n //Get current date elements from Calendar object\n day = cal.get(Calendar.DAY_OF_MONTH);\n month = cal.get(Calendar.MONTH); //Note months are indexed starting at zero (Jan -> 0)\n year = cal.get(Calendar.YEAR);\n\n //Pair EditText to local variable and set input type\n date = (EditText) findViewById(R.id.textSetDate);\n date.setInputType(InputType.TYPE_NULL);\n\n //Set EditText text to be current time\n date.setText((month + 1) + \"/\" + day + \"/\" + year);\n\n //Create onClick listener on date variable\n date.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n datePicker = new DatePickerDialog(ControlCenterActivity.this, new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(DatePicker datePicker, int year, int month, int dayOfMonth) {\n date.setText((month + 1) + \"/\" + dayOfMonth + \"/\" + year);\n }\n }, year, month, day);\n\n datePicker.show();\n }\n });\n }", "private void pickDate(final Calendar initDate){\n //callback for when a date is picked\n DatePickerDialog.OnDateSetListener setDate = new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(DatePicker view, int year, int month, int dayOfMonth) {\n initDate.set(year, month, dayOfMonth,\n initDate.get(Calendar.HOUR_OF_DAY),\n initDate.get(Calendar.MINUTE),\n initDate.get(Calendar.SECOND));\n setDateTimeViews();\n }\n };\n\n DatePickerDialog datePickerDialog = new DatePickerDialog(this,\n setDate, //callback\n initDate.get(Calendar.YEAR), //initial values\n initDate.get(Calendar.MONTH),\n initDate.get(Calendar.DAY_OF_MONTH));\n datePickerDialog.show(); //shows the dialogue\n }", "public void onClick(View v) {\n\t\t\t\tshowDialog(DATE_DIALOG_ID);\r\n\t\t\t}", "@Override\r\n public void onClick(View v) {\n final Calendar c = Calendar.getInstance();\r\n int mYear = c.get(Calendar.YEAR); // current year\r\n int mMonth = c.get(Calendar.MONTH); // current month\r\n int mDay = c.get(Calendar.DAY_OF_MONTH); // current day\r\n\r\n\r\n // date picker dialog\r\n datePickerDialog = new DatePickerDialog(task_setting.this,\r\n new DatePickerDialog.OnDateSetListener() {\r\n\r\n\r\n @Override\r\n public void onDateSet(DatePicker view, int year,\r\n int monthOfYear, int dayOfMonth) {\r\n // set day of month , month and year value in the edit text\r\n\r\n final String[] MONTHS = {\"January\", \"February\", \"March\", \"April\", \"May\", \"June\", \"July\", \"August\", \"September\", \"October\", \"November\", \"December\"};\r\n String mon = MONTHS[monthOfYear];\r\n date.setText(mon + \" \" + dayOfMonth + \", \" + year);\r\n }\r\n }, mYear, mMonth, mDay);\r\n datePickerDialog.getDatePicker().setMinDate(System.currentTimeMillis() - 1000);\r\n datePickerDialog.show();\r\n }", "@Override\n public void onClick(View v) {\n \tToast.makeText(TaskActivity.this, \"Setting dates!\", Toast.LENGTH_SHORT).show();\n \tshowDatePickerDialog(mSelectedYear, mSelectedMonth, mSelectedDay, mOnDateSetListener);\n }", "@Override\n public void onClick(Date date) {\n Event_dialog(date);\n }", "@Override\t\n\t\t\t\tpublic void onClick(View v) {\n\t\t\t\t\tString regDate = (String) btnRegDate.getText();\n\t\t\t\t\tString dateParts[] = regDate.split(\"-\");\n\t\t\t\t\tsetfromday = dateParts[0];\n\t\t\t\t\tsetfrommonth = dateParts[1];\n\t\t\t\t\tsetfromyear = dateParts[2];\n\t\t \n\t\t\t\t\tSystem.out.println(\"regdate is:\"+regDate);\n\t\t\t\t\tshowDialog(REG_DATE_DIALOG_ID);\n\t\t\t\t}", "private void show_Date_Picker() {\n final Calendar c = Calendar.getInstance();\r\n mYear = c.get(Calendar.YEAR);\r\n mMonth = c.get(Calendar.MONTH);\r\n mDay = c.get(Calendar.DAY_OF_MONTH);\r\n android.app.DatePickerDialog datePickerDialog = new android.app.DatePickerDialog(this,\r\n new android.app.DatePickerDialog.OnDateSetListener() {\r\n\r\n @Override\r\n public void onDateSet(DatePicker view, int year,\r\n int monthOfYear, int dayOfMonth)\r\n {\r\n\r\n txt_mfgdate_text.setText(dayOfMonth + \"-\" + (monthOfYear + 1) + \"-\" + year);\r\n\r\n }\r\n }, mYear, mMonth, mDay);\r\n datePickerDialog.show();\r\n\r\n }", "public void showDatepicker(){\n Calendar cal = Calendar.getInstance();\n int year = cal.get(Calendar.YEAR);\n int month = cal.get(Calendar.MONTH)+1;\n int day = cal.get(Calendar.DAY_OF_MONTH);\n new DatePickerDialog(SearchFlightActivity.this, new DatePickerDialog.OnDateSetListener(){\n /**\n * @param datePicker\n * @param i year\n * @param i1 month of year\n * @param i2 day of month\n */\n @Override\n public void onDateSet(DatePicker datePicker, int i, int i1, int i2) {\n et_date.setText(i+\"-\"+i1+\"-\"+i2);\n }\n },year,month,day).show();\n }", "private void showDateStampOptionDialog() {\n\t\t// TODO Auto-generated method stub\n\t\tCharSequence title = res.getString(R.string.setting_datestamp);\n\t\tfinal String[] dateStampUIString = uiDisplayResource\n\t\t\t\t.getDateStampUIString();\n\t\tif (dateStampUIString == null) {\n\t\t\tWriteLogToDevice.writeLog(\"[Error] -- SettingView: \",\n\t\t\t\t\t\"dateStampUIString == null\");\n\t\t\treturn;\n\t\t}\n\t\tint length = dateStampUIString.length;\n\n\t\tint curIdx = 0;\n\t\tUIInfo uiInfo = reflection.refecltFromSDKToUI(\n\t\t\t\tSDKReflectToUI.SETTING_UI_DATE_STAMP,\n\t\t\t\tcameraProperties.getCurrentDateStamp());\n\t\tfor (int i = 0; i < length; i++) {\n\t\t\tif (dateStampUIString[i].equals(uiInfo.uiStringInSetting)) {\n\t\t\t\tcurIdx = i;\n\t\t\t}\n\t\t}\n\n\t\tDialogInterface.OnClickListener listener = new DialogInterface.OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface arg0, int arg1) {\n\t\t\t\tint value = (Integer) reflection.refecltFromUItoSDK(\n\t\t\t\t\t\tUIReflectToSDK.SETTING_SDK_DATE_STAMP,\n\t\t\t\t\t\tdateStampUIString[arg1]);\n\t\t\t\tLog.d(\"tigertiger\", \"----------------value =\" + value);\n\t\t\t\tcameraProperties.setDateStamp(value);\n\t\t\t\targ0.dismiss();\n\t\t\t\tsettingValueList = getSettingValue();\n\t\t\t\tif (optionListAdapter == null) {\n\t\t\t\t\treturn;\n\t\t\t\t}\n\t\t\t\toptionListAdapter.notifyDataSetChanged();\n\t\t\t}\n\t\t};\n\t\tshowOptionDialog(title, dateStampUIString, curIdx, listener, true);\n\t}", "@OnClick(R.id.fragApod_btnSelectDate)\n public void onClickBtnSelectDate(){\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(),\n android.R.style.Theme_DeviceDefault_Light_Panel,\n new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n //Le damos el formato requerido a la fecha seleccionada\n date = new StringBuilder();\n date.append(year).append(\"-\");\n if((monthOfYear+1) < 10) date.append(\"0\");\n date.append(monthOfYear+1).append(\"-\");\n if(dayOfMonth < 10) date.append(\"0\");\n date.append(dayOfMonth);\n\n //LLamamos al método que establece su callback\n apodServiceEnqueue(apodService);\n }\n }, iYear, iMonth, iDay);\n datePickerDialog.show();\n //datePickerDialog.setTitle(getString(R.string.fragApod_msgSelectDate));\n //Sólo puede seleccionar hasta la fecha actual\n datePickerDialog.getDatePicker().setMaxDate(calendar.getTimeInMillis());\n\n //Le restamos 16 años a la fecha actual para ponerla como fecha mínima de selección\n Calendar calendarTemp = Calendar.getInstance();\n calendarTemp.add(calendar.YEAR,-16);\n datePickerDialog.getDatePicker().setMinDate(calendarTemp.getTimeInMillis());\n }", "private void dateOfBirthPicker() {\n _nextActionDate.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n final Calendar c = Calendar.getInstance();\n int mYear = c.get(Calendar.YEAR);\n int mMonth = c.get(Calendar.MONTH);\n int mDay = c.get(Calendar.DAY_OF_MONTH);\n DatePickerDialog dateDialog = new DatePickerDialog(v.getContext(), new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(DatePicker view, int year, int month, int dayOfMonth) {\n Time chosenDate = new Time();\n chosenDate.set(dayOfMonth, month, year);\n long dtDob = chosenDate.toMillis(true);\n\n String format = new SimpleDateFormat(\"yyyy-MM-dd\").format(dtDob);\n _nextActionDate.setText(format);\n\n }\n }, mYear, mMonth, mDay);\n //dateDialog.getDatePicker().setMaxDate(new Date().getTime());\n dateDialog.show();\n }\n });\n }", "@Override\r\n\tpublic void actionPerformed(ActionEvent e)\r\n\t{\r\n\t\tif (e.getSource() == button)\r\n\t\t{\r\n\t\t\t//Get information from calendar\r\n\t\t\tif (datePicker.getModel().getValue() != null)\r\n\t\t\t{\r\n\t\t\t\tDate calendar = (Date) datePicker.getModel().getValue();\r\n\t\t\t\tint month = calendar.getMonth()+1;\r\n\t\t\t\tint day = calendar.getDate();\r\n\t\t\t\tdate = month + \"/\" + day;\r\n\t\t\t\tdispose();\r\n\t\t\t}\r\n\t\t\telse\r\n\t\t\t{\r\n\t\t\t\tdispose();\r\n\t\t\t\tJOptionPane pane = new JOptionPane();\r\n\t\t\t\tpane.setMessage(\"Error: no date chosen\");\r\n\t\t\t\tJDialog dialog = pane.createDialog(null);\r\n\t\t\t\tdialog.setVisible(true);\r\n\t\t\t}\r\n\t\t}\r\n\t\telse\r\n\t\t{\r\n\t\t\tdispose();\r\n\t\t\tJOptionPane pane = new JOptionPane();\r\n\t\t\tpane.setMessage(\"Error: no input\");\r\n\t\t\tJDialog dialog = pane.createDialog(null);\r\n\t\t\tdialog.setVisible(true);\r\n\t\t}\r\n\r\n\t}", "public void setDate(View view) {\n new DatePickerDialog(\n AddEvent.this, dateSet,\n myCalendar.get(Calendar.YEAR),\n myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)\n ).show();\n }", "@Override\n public void onClick(View v) {\n DatePickerDialog dialogoFecha = new DatePickerDialog(CreacionPerfiles.this, (view, year, month, dayOfMonth) ->\n edtFechaNaciento.setText(fechaHora.formatoFecha(dayOfMonth, month, year)), anio, mes, dia);\n dialogoFecha.show();\n }", "private void showDatePickerDialog() {\n DatePickerDialog datePickerDialog = new DatePickerDialog(\n this,\n this,\n Calendar.getInstance().get(Calendar.YEAR),\n Calendar.getInstance().get(Calendar.MONTH),\n Calendar.getInstance().get(Calendar.DAY_OF_MONTH)\n );\n datePickerDialog.show();\n }", "public int showDateTimeDialog()\n\t{\n\t\treturn showDialog(owner, layoutPanel, SwingLocale.getString(\"date_time_selector\"), IconFactory.getSwingIcon(\"component/calendar_48.png\"));\n\t}", "@Override\n public void onClick(View v) {\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(), new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(android.widget.DatePicker view, int year, int month, int dayOfMonth) {\n month = month + 1;\n String date =String.format(\"%02d/%02d/%d\", dayOfMonth,month, year);\n TextViewCheckIn.setText(date);\n\n }\n },year,month,day);\n long today = Calendar.getTimeInMillis();\n datePickerDialog.getDatePicker().setMinDate(today);\n datePickerDialog.show();\n }", "public void showDatePickerDialog(){\n DatePickerDialog datePickerDialog = new DatePickerDialog(\n this,\n this,\n Calendar.getInstance().get(Calendar.YEAR),\n Calendar.getInstance().get(Calendar.MONTH),\n Calendar.getInstance().get(Calendar.DAY_OF_MONTH));\n datePickerDialog.show();\n }", "public void setSelectedDate(Date selectedDate);", "@SuppressLint(\"InlinedApi\")\n @Override\n public void onClick(View v) {\n @SuppressLint({\"NewApi\", \"LocalSuppress\"}) final Calendar mcurrentDate = Calendar.getInstance();\n int mYear = mcurrentDate.get(Calendar.YEAR);\n int mMonth = mcurrentDate.get(Calendar.MONTH);\n int mDay = mcurrentDate.get(Calendar.DAY_OF_MONTH);\n\n DatePickerDialog mDatePicker = new DatePickerDialog(Addnewuser.this, new DatePickerDialog.OnDateSetListener() {\n\n public void onDateSet(DatePicker datepicker, int selectedyear, int selectedmonth, int selectedday) {\n mybirthday = new GregorianCalendar(selectedyear, selectedmonth, selectedday).getTime();\n birthday = \"\" + selectedday + \"/\" + (selectedmonth + 1) + \"/\" + selectedyear + \"\";\n dob.setText(birthday);\n // Toast.makeText(Addnewuser.this, \"\"+birthday+\"\\n\" +\n // \"\"+date.toString(), Toast.LENGTH_SHORT).show();\n\n\n }\n }, mYear, mMonth, mDay);\n mDatePicker.setTitle(\"Select date\");\n mDatePicker.show();\n }", "public void setPickerDate(@NonNull final LocalDateTime date) {\n onView(viewMatcher).perform(click());\n onView(withClassName(equalTo(DatePicker.class.getName())))\n .perform(PickerActions.setDate(date.getYear(), date.getMonth().getValue(), date.getDayOfMonth()));\n new Dialog().confirmDialog();\n }", "private void showDialogTime() {\n final TimePickerDialog timePickerDialog = new TimePickerDialog(getActivity(),\n new TimePickerDialog.OnTimeSetListener() {\n\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n\n mCal.set(Calendar.HOUR_OF_DAY, hourOfDay);\n mCal.set(Calendar.MINUTE, minute);\n\n tvDate.setText(getDateString(mCal));\n\n }\n }, mCal.get(Calendar.HOUR_OF_DAY), mCal.get(Calendar.MINUTE), true);\n\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(),\n new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n mCal.set(Calendar.YEAR, year);\n mCal.set(Calendar.MONTH, monthOfYear);\n mCal.set(Calendar.DAY_OF_MONTH, dayOfMonth);\n\n timePickerDialog.show();\n }\n }, mCal.get(Calendar.YEAR), mCal.get(Calendar.MONTH), mCal.get(Calendar.DAY_OF_MONTH));\n datePickerDialog.show();\n }", "private void ShowDatePickerDialog() {\n\r\n\t\tfinal Calendar c = Calendar.getInstance();\r\n\t\tint mYear = c.get(Calendar.YEAR);\r\n\t\tint mMonth = c.get(Calendar.MONTH);\r\n\t\tint mDay = c.get(Calendar.DAY_OF_MONTH);\r\n\r\n\t\tDatePickerDialog datepicker = new DatePickerDialog(getActivity(),\r\n\t\t\t\tdatePickerListener, mYear, mMonth, mDay);\r\n\t\tdatepicker.getDatePicker()\r\n\t\t\t\t.setMinDate(System.currentTimeMillis() - 1000);\r\n\t\tdatepicker.show();\r\n\r\n\t}", "@Override\n public void onClick(final View v) {\n\n final Calendar now = Calendar.getInstance();\n final DatePickerDialog dpd = DatePickerDialog.newInstance(\n new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(DatePickerDialog datePickerDialog, int i, int i1, int i2) {\n now.set(i, i1, i2);\n TextView tv = (TextView) view.findViewById(R.id.product_bookingdate_tv);\n if(SimpleDateFormat.getDateInstance().format(now.getTime()).equals(SimpleDateFormat.getDateInstance().format(Calendar.getInstance().getTime()))) {\n MsgUtils.showToast(getActivity(), MsgUtils.TOAST_TYPE_NO_CURRENT_BOOKING_DATE, null, MsgUtils.ToastLength.LONG);\n return;\n }\n else\n tv.setText(SimpleDateFormat.getDateInstance().format(now.getTime()));\n }\n },\n now.get(Calendar.YEAR),\n now.get(Calendar.MONTH),\n now.get(Calendar.DAY_OF_MONTH)\n );\n dpd.setThemeDark(true);\n dpd.vibrate(true);\n dpd.dismissOnPause(true);\n //dpd.setAccentColor(Color.parseColor(\"#9C27B0\"));\n dpd.setTitle(\"Booking Date\");\n\n //***********************\n //Limit Dates\n //***********************\n\n dpd.setMinDate(now);\n\n /*ArrayList<Calendar> lDates = new ArrayList();\n for (int i = 0; i <= 2; i++) {\n Calendar date = Calendar.getInstance();\n date.add(Calendar.MONTH, i);\n lDates.add(date);\n }\n\n Calendar[] lCalendarArray = lDates.toArray(new Calendar[lDates.size()]);\n dpd.setSelectableDays(lCalendarArray);*/\n\n //***********************\n //Disable Advanced Booking Dates\n //***********************\n\n int advancedBookingDays = 0;\n\n for(ProductAttributeGroups pag : selectedProduct.getAttributeGroups()) {\n for(ProductAttributes pa : pag.getProductAttributes()) {\n if (pa.getName().toLowerCase().equals(CONST.OPTION_ATTRIBUTE_BOOKING)) {\n if (pa.getText() != null || pa.getText() != \"\")\n advancedBookingDays = Integer.valueOf(pa.getText());\n else\n advancedBookingDays = 1;\n }\n }\n }\n\n ArrayList<Calendar> bDates = new ArrayList();\n for (int i = 0; i < advancedBookingDays; i++) {\n Calendar date = Calendar.getInstance();\n date.add(Calendar.DAY_OF_MONTH, i+1);\n bDates.add(date);\n }\n\n /*Calendar currentDate = Calendar.getInstance();\n currentDate.add(Calendar.DAY_OF_MONTH, 0);\n bDates.add(0, currentDate);*/\n\n Calendar[] calendarArray = bDates.toArray(new Calendar[bDates.size()]);\n dpd.setDisabledDays(calendarArray);\n\n dpd.show(getActivity().getFragmentManager(), \"Date Picker\");\n\n if(bookingDateTv.getText() != null || bookingDateTv.getText() != \"\")\n upateTimeSpinner(selectedProduct);\n }", "public void onClick(View view) {\n\t\t\t\t\tf=1;f1=0;\n\t\t \t\tsyear=myCalendar.get(Calendar.YEAR);\n\t\t \t\tsmonth=myCalendar.get(Calendar.MONTH);\n\t\t \t\tsday=myCalendar.get(Calendar.DAY_OF_MONTH);\n\t\t\t\t\tnew DatePickerDialog(getActivity(), date, myCalendar\n\t\t .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n\t\t myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n\t\t\t\t}", "private void showDatePicker() {\n DatePickerFragmentCreditCard date = new DatePickerFragmentCreditCard();\n /**\n * Set Up Current Date Into dialog\n */\n Calendar calendar = Calendar.getInstance();\n Bundle args = new Bundle();\n args.putInt(\"year\", calendar.get(Calendar.YEAR));\n args.putInt(\"month\", calendar.get(Calendar.MONTH));\n args.putInt(\"day\", calendar.get(Calendar.DAY_OF_MONTH));\n args.putLong(\"currentDateInMillis\", calendar.getTimeInMillis());\n date.setArguments(args);\n /**\n * Set Call back to capture selected date\n */\n date.setCallBack(ondate);\n date.show(getFragmentManager(), \"Date Picker\");\n\n }", "public void showDateTimePickerDialog(final EditText view) {\n final Dialog dialog = new Dialog(getActivity());\n dialog.setContentView(R.layout.dialog_viewing_time);\n dialog.setTitle(\"Select Viewing Date\");\n final StringBuilder selectedDateTime = new StringBuilder();\n final DatePicker datePicker = (DatePicker) dialog.findViewById(R.id.datePicker);\n\n Button selectDateTimeButton = (Button) dialog.findViewById(R.id.selectDateTimeButton);\n\n selectDateTimeButton.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n selectedDateTime.append(datePicker.getDayOfMonth())\n .append(ApplicationConstants.DATE_SEPERATOR)\n .append(datePicker.getMonth() + 1)\n .append(ApplicationConstants.DATE_SEPERATOR)\n .append(datePicker.getYear());\n view.setText(selectedDateTime.toString());\n dialog.dismiss();\n }\n });\n\n dialog.show();\n }", "@Override\n\t\t\t\t\t\t\tpublic void onClick(View v) {\n\t\t\t\t\t\t\t\t DatePickerDialog mDatePicker=new DatePickerDialog(contextyeild, new OnDateSetListener() { \n\t\t\t\t\t\t public void onDateSet(DatePicker datepicker, int selectedyear, int selectedmonth, int selectedday) {\n\t\t\t\t\t\t // TODO Auto-generated method stub \n\t\t\t\t\t\t /* Your code to get date and time */\n\t\t\t\t\t\t \t//final Calendar c = Calendar.getInstance();\n\t\t\t\t\t\t \t\t//\tc.set(selectedyear, selectedmonth, selectedday);\n\t\t\t\t\t\t \t\t\tstart_day = selectedday;\n\t\t\t\t\t\t \t\t\tstart_month = selectedmonth;\n\t\t\t\t\t\t \t\t\tstart_year = selectedyear;\n\t\t\t\t\t\t \t\t\t//final Date date = new Date(c.getTimeInMillis());\n\t\t\t\t\t\t \t\t\t//final SimpleDateFormat dateFormat = new SimpleDateFormat(\"yyyy-MM-dd\");\n\t\t\t\t\t\t \t\t\t//harvestdate1.setText(dateFormat.format(date));\n\t\t\t\t\t\t harvestdate1.setText(new StringBuilder().append(start_day).append(\"-\").append(start_month+1)\n\t\t\t\t\t .append(\"-\").append(start_year)\n\t\t\t\t\t .append(\" \")); \t\n\t\t\t\t\t\t // set selected date into Date Picker\n\t\t\t\t\t\t datepicker.init(start_year, start_month, start_day, null);\n\n\t\t\t\t\t\t }\n\t\t\t\t\t\t },start_year, start_month, start_day);\n\t\t\t\t\t\t mDatePicker.setTitle(\"Select date\"); \n\t\t\t\t\t\t mDatePicker.show(); \n\t\t\t\t\t\t\t}", "public void showDateDialog(View v) {\n Calendar newCalendar = Calendar.getInstance();\n\n /**\n * Initiate DatePicker dialog\n */\n datePickerDialog = new DatePickerDialog(this, new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n /**\n * Method ini dipanggil saat kita selesai memilih tanggal di DatePicker\n */\n\n /**\n * Set Calendar untuk menampung tanggal yang dipilih\n */\n Calendar newDate = Calendar.getInstance();\n newDate.set(year, monthOfYear, dayOfMonth);\n\n /**\n * Update TextView dengan tanggal yang kita pilih\n */\n if (v == mBtnDate)\n mTglLahir.setText(dateFormatter.format(newDate.getTime()));\n else if (v == mBtnDateMasuk)\n mTglMasuk.setText(dateFormatter.format(newDate.getTime()));\n else if (v == mBtnDateLulus)\n mTglLulus.setText(dateFormatter.format(newDate.getTime()));\n else if (v == mBtnMasukKerja)\n mTglMasukKerja.setText(dateFormatter.format(newDate.getTime()));\n\n }\n }, newCalendar.get(Calendar.YEAR), newCalendar.get(Calendar.MONTH), newCalendar.get(Calendar.DAY_OF_MONTH));\n\n /**\n * Tampilkan DatePicker dialog\n */\n datePickerDialog.show();\n }", "@Override\n public void onClick(View v) {\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(), new DatePickerDialog.OnDateSetListener() {\n @Override\n public void onDateSet(android.widget.DatePicker view, int year, int month, int dayOfMonth) {\n month = month + 1;\n String date =String.format(\"%02d/%02d/%d\", dayOfMonth,month, year);\n TextViewCheckOut.setText(date);\n long today = Calendar.getTimeInMillis();\n view.setMinDate(today);\n }\n },year,month,day);\n long today = Calendar.getTimeInMillis();\n datePickerDialog.getDatePicker().setMinDate(today);\n //memunculkan pilihan pada UI\n datePickerDialog.show();\n }", "@Override\n\t\tpublic void onClick(final View v) {\n\t\t\t\n\t\t\tint y,m,d;\n\t\t\t\n\t\t\tCalendar c = Calendar.getInstance();\n\t\t\t\n\t\t\ty=c.get(Calendar.YEAR);\n\t\t\tm=c.get(Calendar.MONTH);\n\t\t\td=c.get(Calendar.DAY_OF_MONTH);\n\t\t\t\n\t\t\tDatePickerDialog dpd = new DatePickerDialog(ADD2Activity.this, new OnDateSetListener() {\n\t\t\t\t\n\t\t\t\t@Override\n\t\t\t\tpublic void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\t\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\t\tEditText et = (EditText) v;\n\t\t\t\t\t\n\t\t\t\t\tet.setText(\"\" + dayOfMonth +\"-\" + monthOfYear + \"-\" + (year%100));\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}, y, m, d); \n\t\t\t\n\t\t\tdpd.show();\n\t\t\t\n\t\t\t\n\t\t\t\n\t\t}", "@Override\n public void onDateSet(DatePicker view, int selectedYear,\n int selectedMonth, int selectedDay) {\n\n year = selectedYear;\n month = selectedMonth;\n day = selectedDay;\n\n showDialog(AppUtils.TIME_DIALOG_ID);\n\n }", "@Override\n\t\t\t\t\t\t\tpublic void onClick(View v) {\n\t\t\t\t\t\t\t\n\n\t\t\t\t\t DatePickerDialog mDatePicker=new DatePickerDialog(contextyeild, new OnDateSetListener() { \n\t\t\t\t\t public void onDateSet(DatePicker datepicker, int selectedyear, int selectedmonth, int selectedday) {\n\t\t\t\t\t // TODO Auto-generated method stub \n\t\t\t\t\t /* Your code to get date and time */\n\t\t\t\t\t \t//final Calendar c = Calendar.getInstance();\n\t\t\t\t\t \t\t//\tc.set(selectedyear, selectedmonth, selectedday);\n\t\t\t\t\t \t\t\tstart_day = selectedday;\n\t\t\t\t\t \t\t\tstart_month = selectedmonth;\n\t\t\t\t\t \t\t\tstart_year = selectedyear;\n\t\t\t\t\t \t\t\t//final Date date = new Date(c.getTimeInMillis());\n\t\t\t\t\t \t\t\t//final SimpleDateFormat dateFormat = new SimpleDateFormat(\"yyyy-MM-dd\");\n\t\t\t\t\t \t\t\t//harvestdate1.setText(dateFormat.format(date));\n\t\t\t\t\t harvestdate1.setText(new StringBuilder().append(start_day).append(\"-\").append(start_month+1)\n\t\t\t\t .append(\"-\").append(start_year)\n\t\t\t\t .append(\" \")); \t\n\t\t\t\t\t // set selected date into Date Picker\n\t\t\t\t\t datepicker.init(start_year, start_month, start_day, null);\n\n\t\t\t\t\t }\n\t\t\t\t\t },start_year, start_month, start_day);\n\t\t\t\t\t mDatePicker.setTitle(\"Select date\"); \n\t\t\t\t\t mDatePicker.show(); \n\t\t\t\t\t\t\t}", "@Override\n public void onDateSet(DatePickerDialog view, int year, int month, int date)\n {\n String dateSet = \"\" + year + \"-\" + (++month) + \"-\" + date;\n selectDateTextView.setText(dateSet);\n\n\n\n\n// _device_id = \"2345\";\n// _expiry_date = T.parseDate(dateSet);\n// _document_type = \"Driving Licence\";\n//\n// uploadDocumentImage();\n }", "public void showDateDialog(View v) {\n Calendar newCalendar = Calendar.getInstance();\n\n /**\n * Initiate DatePicker dialog\n */\n datePickerDialog = new DatePickerDialog(this, new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n /**\n * Method ini dipanggil saat kita selesai memilih tanggal di DatePicker\n */\n\n /**\n * Set Calendar untuk menampung tanggal yang dipilih\n */\n Calendar newDate = Calendar.getInstance();\n newDate.set(year, monthOfYear, dayOfMonth);\n\n /**\n * Update TextView dengan tanggal yang kita pilih\n */\n if (v == mBtnDate)\n mTglLahir.setText(dateFormatter.format(newDate.getTime()));\n else if (v == mBtnDateAnak)\n mTglLahirAnak.setText(dateFormatter.format(newDate.getTime()));\n else if (v == mBtnDateTanggungan)\n mTglLahirTanggungan.setText(dateFormatter.format(newDate.getTime()));\n }\n }, newCalendar.get(Calendar.YEAR), newCalendar.get(Calendar.MONTH), newCalendar.get(Calendar.DAY_OF_MONTH));\n\n /**\n * Tampilkan DatePicker dialog\n */\n datePickerDialog.show();\n }", "public void onClick(View view) {\n\t\t\t\t\tf1=1;f=0;\n\t\t\t\t\teyear=myCalendar.get(Calendar.YEAR);\n\t\t \t\temonth=myCalendar.get(Calendar.MONTH);\n\t\t \t\teday=myCalendar.get(Calendar.DAY_OF_MONTH);\n\t\t \t\tnew DatePickerDialog(getActivity(), date, myCalendar\n\t\t .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n\t\t myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n\t\t\t\t}", "public void selectDate(String d){\n\t\tDate current = new Date();\n\t\tSimpleDateFormat sd = new SimpleDateFormat(\"d-MM-yyyy\");\n\t\ttry {\n\t\t\tDate selected = sd.parse(d);\n\t\t\tString day = new SimpleDateFormat(\"d\").format(selected);\n\t\t\tString month = new SimpleDateFormat(\"MMMM\").format(selected);\n\t\t\tString year = new SimpleDateFormat(\"yyyy\").format(selected);\n\t\t\tSystem.out.println(day+\" --- \"+month+\" --- \"+ year);\n\t\t\tString desiredMonthYear=month+\" \"+year;\n\t\t\t\n\t\t\twhile(true){\n\t\t\t\tString displayedMonthYear=driver.findElement(By.cssSelector(\".dpTitleText\")).getText();\n\t\t\t\tif(desiredMonthYear.equals(displayedMonthYear)){\n\t\t\t\t\t// select the day\n\t\t\t\t\tdriver.findElement(By.xpath(\"//td[text()='\"+day+\"']\")).click();\n\t\t\t\t\tbreak;\n\t\t\t\t}else{\n\t\t\t\t\t\n\t\t\t\t\tif(selected.compareTo(current) > 0)\n\t\t\t\t\t\tdriver.findElement(By.xpath(\"//*[@id='datepicker']/table/tbody/tr[1]/td[4]/button\")).click();\n\t\t\t\t\telse if(selected.compareTo(current) < 0)\n\t\t\t\t\t\tdriver.findElement(By.xpath(\"//*[@id='datepicker']/table/tbody/tr[1]/td[2]/button\")).click();\n\n\t\t\t\t}\n\t\t\t}\n\n\t\t} catch (ParseException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\t\n\t}", "private void launchDatePicker(DatePickerDialog.OnDateSetListener dateSetListener) {\n // Create Calendar object\n Calendar cal = Calendar.getInstance();\n // get year, month and day\n int year = cal.get(Calendar.YEAR);\n int month = cal.get(Calendar.MONTH);\n int day = cal.get(Calendar.DAY_OF_MONTH);\n // Create the DatePickerDialog object\n DatePickerDialog dialog = new DatePickerDialog(this,android.R.style.Widget_Material_DatePicker, dateSetListener,year,month,day);\n // Show the dialog\n dialog.show();\n }", "public Date getSelectDate();", "public void showStartDateDialog(View v){\n DialogFragment dialogFragment = null;\n switch (v.getId()) {\n case R.id.newEvent_button_from:\n dialogFragment = new StartDatePicker(0);\n break;\n case R.id.newEvent_button_to:\n dialogFragment = new StartDatePicker(1);\n break;\n }\n dialogFragment.show(getFragmentManager(), \"start_date_picker\");\n }", "@Override\n public void onClick(View v) {\n MmxDate dateTime = new MmxDate(getPaymentDate());\n\n CalendarDatePickerDialogFragment datePicker = new CalendarDatePickerDialogFragment()\n .setFirstDayOfWeek(dateUtils.getFirstDayOfWeek())\n .setOnDateSetListener(listener)\n .setPreselectedDate(dateTime.getYear(), dateTime.getMonth() - 1, dateTime.getDayOfMonth());\n if (new UIHelper(RecurringTransactionEditActivity.this).isUsingDarkTheme()) {\n datePicker.setThemeDark();\n }\n datePicker.show(getSupportFragmentManager(), TAG_DATEPICKER);\n }", "@Override\r\n\tpublic void dateDialogCallBack(String date) {\n\t\tnoteGlobal.dateString=date;\r\n\t\tnoteGlobal.getPlan(date);\r\n\t\tdateTextView.setText(date);\r\n\t\tdateString = date;\r\n\t\taddPlan_View();\r\n\t}", "private void setDateButtonActionPerformed(java.awt.event.ActionEvent evt) {\n Date newDate = calendario.getDate();\n if(newDate != null) {\n java.sql.Date date = new java.sql.Date(newDate.getTime());\n control.setDate(date);\n control.crearAlerta(\"Informacion\", \"La fecha \" + date + \" ha sido agregada\" , this);\n } else {\n control.crearAlerta(\"Advertencia\", \"Debe escoger una fecha\", this);\n }\n }", "protected String getSelectedDate()\n {\n String startsOnDate = String.valueOf(selectedYear);\n if(selectedMonth<10)startsOnDate+=\"-0\"+String.valueOf(selectedMonth);\n else startsOnDate+=\"-\"+String.valueOf(selectedMonth);\n if(selectedDay<10)startsOnDate+=\"-0\"+String.valueOf(selectedDay);\n else startsOnDate+=\"-\"+String.valueOf(selectedDay);\n\n return startsOnDate;\n }", "private void DateDialogPicker(DatePickerDialog.OnDateSetListener listener) {\n final Calendar c = Calendar.getInstance();\n int year = c.get(Calendar.YEAR);\n int month = c.get(Calendar.MONTH);\n int day = c.get(Calendar.DAY_OF_MONTH);\n\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(),\n listener, year, month, day);\n\n datePickerDialog.show();\n }", "@Override\n public void onClick(View v) {\n final Calendar c = Calendar.getInstance();\n int mYear = c.get(Calendar.YEAR); // current year\n int mMonth = c.get(Calendar.MONTH); // current month\n int mDay = c.get(Calendar.DAY_OF_MONTH); // current day\n // date picker dialog\n datePickerDialog = new DatePickerDialog(ChangeProfileActivity.this,\n new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year,\n int monthOfYear, int dayOfMonth) {\n // set day of month , month and year value in the edit text\n txtdate.setText(dayOfMonth + \"/\"\n + (monthOfYear + 1) + \"/\" + year);\n\n }\n }, mYear, mMonth, mDay);\n datePickerDialog.show();\n }", "@Override\n public void onClick(View view) {\n dateDialog.show(getFragmentManager(), \"datePicker\");\n }", "public void pickDate() {\n DialogFragment newFragment = new MyDatePicker();\n newFragment.show(getFragmentManager(), \"datepicker\");\n Bundle bundle = new Bundle();\n bundle.putInt(\"id\", 1);\n newFragment.setArguments(bundle);\n\n\n }" ]
[ "0.74876356", "0.73822635", "0.7380768", "0.7334227", "0.7330351", "0.7312856", "0.72907674", "0.7250154", "0.7242669", "0.72398984", "0.7224816", "0.72227967", "0.7214459", "0.71911323", "0.7178382", "0.7178382", "0.7173564", "0.7172434", "0.71649104", "0.7158146", "0.71502703", "0.71487623", "0.71293557", "0.71293557", "0.71078056", "0.70874125", "0.70872426", "0.70622396", "0.70582914", "0.70549554", "0.7038937", "0.702639", "0.7011196", "0.7006167", "0.6988221", "0.69834167", "0.6965231", "0.6965231", "0.69547695", "0.6948517", "0.69381374", "0.6930727", "0.6902567", "0.69024926", "0.68941486", "0.6892306", "0.6891361", "0.6865522", "0.6799853", "0.6776655", "0.6770589", "0.67660624", "0.67648005", "0.6756721", "0.6753844", "0.6749465", "0.6739354", "0.6722202", "0.670331", "0.66848886", "0.66311723", "0.66254437", "0.6612117", "0.6568367", "0.6561909", "0.6557475", "0.65436625", "0.6542516", "0.6534649", "0.6519542", "0.65056086", "0.65004295", "0.64994675", "0.64797723", "0.64751315", "0.64717", "0.6469506", "0.646901", "0.6460784", "0.6454626", "0.64519316", "0.6447556", "0.6439567", "0.64335865", "0.64293754", "0.6427518", "0.64235985", "0.6414739", "0.6402105", "0.63932586", "0.63930744", "0.6392464", "0.63922167", "0.63727754", "0.63712364", "0.6368212", "0.63557637", "0.6354227", "0.63486797", "0.6345841" ]
0.8089274
0
Opens a dialog to choose the time with predefined date values (the current ones).
private void chooseTimeDialog() { Calendar c = Calendar.getInstance(); int hourOfDay = c.get(Calendar.HOUR_OF_DAY); int minute = c.get(Calendar.MINUTE); TimePickerDialog timePickerDialog = new TimePickerDialog(getContext(), this, hourOfDay, minute, false); timePickerDialog.show(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void showDialogTime() {\n final TimePickerDialog timePickerDialog = new TimePickerDialog(getActivity(),\n new TimePickerDialog.OnTimeSetListener() {\n\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n\n mCal.set(Calendar.HOUR_OF_DAY, hourOfDay);\n mCal.set(Calendar.MINUTE, minute);\n\n tvDate.setText(getDateString(mCal));\n\n }\n }, mCal.get(Calendar.HOUR_OF_DAY), mCal.get(Calendar.MINUTE), true);\n\n DatePickerDialog datePickerDialog = new DatePickerDialog(getActivity(),\n new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n mCal.set(Calendar.YEAR, year);\n mCal.set(Calendar.MONTH, monthOfYear);\n mCal.set(Calendar.DAY_OF_MONTH, dayOfMonth);\n\n timePickerDialog.show();\n }\n }, mCal.get(Calendar.YEAR), mCal.get(Calendar.MONTH), mCal.get(Calendar.DAY_OF_MONTH));\n datePickerDialog.show();\n }", "private void showTimeDialog() {\n\t\tTimePickerDialog tpd = new TimePickerDialog(this, new OnTimeSetListener(){\r\n\t\t\tpublic void onTimeSet(TimePicker view , int hour, int minute){\r\n\t\t\t\tgiorno.set(Calendar.HOUR_OF_DAY,hour);\r\n\t\t\t\tgiorno.set(Calendar.MINUTE,minute); \r\n\t\t\t\tEditText et_ora = (EditText) BookingActivity.this.findViewById(R.id.prenotazione_et_ora);\r\n\t\t\t\tformatter.applyPattern(\"HH:mm\");\r\n\t\t\t\tet_ora.setText(formatter.format(giorno.getTime()));\r\n\t\t\t}\t\t\t \t\r\n\t\t}, giorno.get(Calendar.HOUR_OF_DAY), giorno.get(Calendar.MINUTE), true);\r\n\t\ttpd.show();\r\n\t}", "public int showDateTimeDialog()\n\t{\n\t\treturn showDialog(owner, layoutPanel, SwingLocale.getString(\"date_time_selector\"), IconFactory.getSwingIcon(\"component/calendar_48.png\"));\n\t}", "private void timeSelectionDialog() {\n final TimeSelectionDialog timeSelectDialog = new TimeSelectionDialog(this, _game);\n timeSelectDialog.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n _game.setTime(timeSelectDialog.getSelectedTime());\n timeSelectDialog.dismiss();\n }\n });\n timeSelectDialog.show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(select_time_date.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "private void chooseDateDialog() {\n Calendar c = Calendar.getInstance();\n int year = c.get(Calendar.YEAR);\n int month = c.get(Calendar.MONTH);\n int day = c.get(Calendar.DATE);\n\n DatePickerDialog datePickerDialog =\n new DatePickerDialog(Objects.requireNonNull(getContext()), this, year, month, day);\n datePickerDialog.show();\n }", "@Override\n public void onClick(View v) {\n new TimePickerDialog(getActivity(), starttimepicker, trigger.getStarttime().get(Calendar.HOUR), trigger.getStarttime().get(Calendar.MINUTE), true).show();\n }", "@Override\n public void onClick(View v) {\n showDialog(TIME_DIALOG_ID);\n }", "@Override\n public void onClick(View v) {\n long epochTime = getCurrentTimeSetting();\n Calendar cal = Calendar.getInstance();\n cal.setTimeInMillis(epochTime);\n\n int id = v.getId();\n switch (id) {\n case R.id.text_date:\n DatePickerDialog datePickerDialog = new DatePickerDialog(\n mContext, this,\n cal.get(Calendar.YEAR), cal.get(Calendar.MONTH), cal.get(Calendar.DAY_OF_MONTH)\n );\n datePickerDialog.show();\n break;\n case R.id.text_clock:\n TimePickerDialog timePickerDialog = new TimePickerDialog(\n mContext, this,\n cal.get(Calendar.HOUR_OF_DAY), cal.get(Calendar.MINUTE), false\n );\n timePickerDialog.show();\n break;\n }\n }", "@Override\n public void onClick(View v) {\n new TimePickerDialog(getActivity(), endtimepicker, trigger.getEndtime().get(Calendar.HOUR), trigger.getEndtime().get(Calendar.MINUTE), true).show();\n }", "private void selectTime() {\n Calendar calendar = Calendar.getInstance();\n int hour = calendar.get(Calendar.HOUR_OF_DAY);\n int minute = calendar.get(Calendar.MINUTE);\n TimePickerDialog timePickerDialog = new TimePickerDialog(this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int i, int i1) {\n timeTonotify = i + \":\" + i1; //temp variable to store the time to set alarm\n mTimebtn.setText(FormatTime(i, i1)); //sets the button text as selected time\n }\n }, hour, minute, false);\n timePickerDialog.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog42 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t42Hour42 = hourOfDay1;\n t42Minute42 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t42Hour42, t42Minute42);\n //set selected time on text view\n\n\n timeE21 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime21.setText(timeE21);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog42.updateTime(t42Hour42, t42Minute42);\n //show dialog\n timePickerDialog42.show();\n }", "public void selectDate(){\r\n\t\tcloseDateText.sendKeys(ConvertDate());\r\n\t}", "private void showTimePicker(){\n\n // Create new time picker instance\n TimePickerDialog timePicker = new TimePickerDialog(this, (view, hourOfDay, minute) -> {\n // Update booking time\n bookingHour = hourOfDay;\n bookingMinute = minute;\n\n // Set the contents of the edit text to the relevant hours / minutes\n timeInput.setText(getString(R.string.desired_time_format, bookingHour, bookingMinute));\n\n }, bookingHour, bookingMinute, true);\n\n timePicker.setTitle(getString(R.string.desired_time_selection));\n timePicker.show();\n\n // Change button colors\n Button positiveButton = timePicker.getButton(AlertDialog.BUTTON_POSITIVE);\n positiveButton.setTextColor(getColor(R.color.colorPrimary));\n Button negativeButton = timePicker.getButton(AlertDialog.BUTTON_NEGATIVE);\n negativeButton.setTextColor(getColor(R.color.colorPrimary));\n }", "@Override\n public void onClick(View v) {\n Calendar mcurrentTime = Calendar.getInstance();\n int hour = mcurrentTime.get(Calendar.HOUR_OF_DAY);\n int minute = mcurrentTime.get(Calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(AddRDV.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n editTextHeur.setText(String.format(\"%02d\",selectedHour) + \":\" + String.format(\"%02d\" ,selectedMinute)+\":\"+\"00\");\n }\n }, hour, minute, true);//Yes 24 hour time\n mTimePicker.setTitle(\"Select time of your appointment\");\n mTimePicker.show();\n\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog20 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t20Hour20 = hourOfDay1;\n t20Minute20 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t20Hour20, t20Minute20);\n //set selected time on text view\n\n\n timeE10 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime10.setText(timeE10);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog20.updateTime(t20Hour20, t20Minute20);\n //show dialog\n timePickerDialog20.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog40 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t40Hour40 = hourOfDay1;\n t40Minute40 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t40Hour40, t40Minute40);\n //set selected time on text view\n\n\n timeE20 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime20.setText(timeE20);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog40.updateTime(t40Hour40, t40Minute40);\n //show dialog\n timePickerDialog40.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog39 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t39Hour39 = hourOfDay1;\n t39Minute39 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t39Hour39, t39Minute39);\n //set selected time on text view\n\n\n timeS20 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime20.setText(timeS20);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog39.updateTime(t39Hour39, t39Minute39);\n //show dialog\n timePickerDialog39.show();\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), startdatepicker, trigger.getStarttime().get(Calendar.YEAR), trigger.getStarttime().get(Calendar.MONTH), trigger.getStarttime().get(Calendar.DAY_OF_MONTH)).show();\n }", "private void showChooseCurNonGarTimeDialog2(){\n\t\talertDialog = new AlertDialog.Builder(this);\n\t\talertDialog.setTitle(\"请选择添到店时间\");\n\t\ttimeString = new String[] {\"23:59\",\"次日06:00\"};\n\t\tfinal ArrayList<String> arrayList = new ArrayList<String>();\n\t\t//final ArrayList<String> arrayListType = new ArrayList<String>();\n\n\t\tfor (int i = 0; i < timeString.length; i++) {\n\t\t\tif (!timeString[i].equals(\"null\")) {\n\t\t\t\tarrayList.add(timeString[i]);\t\n\t\t\t\t//arrayListType.add(typeArrayStrings[i]);\n\n\t\t\t}\n\t\t}\n\t\t//将遍历之后的数组 arraylist的内容在选择器上显示 \n\t\talertDialog.setSingleChoiceItems(arrayList.toArray(new String[0]), 0, new DialogInterface.OnClickListener(){\n\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tdialog.dismiss();\n\t\t\t\tSystem.out.println(\"***被点击***\"+which);\n\t\t\t\tdialog.toString();\n\t\t\t\tswitch (which) {\n\t\t\t\tcase 0:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = (getTimeCurrentHr()+1)+\":00\"+\"-\"+\"23:59\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" + (getTimeCurrentHr()+1)+\":00:00\";\n\t\t\t\t\tpostArrivalLateTime = leaveTimeString + \" \" + \"23:59:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\t\t\n\t\t\t\tcase 1:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"23:59-次日06:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"23:59:00\" ;\n\t\t\t\t\tpostArrivalLateTime = getDateNext(liveTimeString)+ \" \" + \"06:00:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tint dayNum1 = Integer.parseInt(dayTextView.getText().toString());\n\t\t\t\t\tint roomNum1 = Integer.parseInt(roomtTextView.getText().toString());\n\t\t\t\t\tif(dayNum1 != 1){\n\t\t\t\t\t\t//dayTextView.setText(\"\"+(dayNum1+1));\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+((j/dayNum1)*(dayNum1-1)*roomNum1));\n\t\t\t\t\t}else{\n\t\t\t\t\t\t//dayTextView.setText(\"1\");\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+(j*1*roomNum1));\n\t\t\t\t\t}\n\t\t\t\t\tbreak;\t\t\t\t\t\t\n\t\t\t\tdefault:\n\t\t\t\t\tarrivingTime = \"\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t}).show();\n\t}", "private void showChooseNonCurNonGarTimeDialog(){\n\t\talertDialog = new AlertDialog.Builder(this);\n\t\talertDialog.setTitle(\"请选择添到店时间\");\n\t\ttimeString = new String[] { \"20:00\", \"23:59\",\"次日06:00\"};\n\t\tfinal ArrayList<String> arrayList = new ArrayList<String>();\n\t\t//final ArrayList<String> arrayListType = new ArrayList<String>();\n\n\t\tfor (int i = 0; i < timeString.length; i++) {\n\t\t\tif (!timeString[i].equals(\"null\")) {\n\t\t\t\tarrayList.add(timeString[i]);\t\n\t\t\t\t//arrayListType.add(typeArrayStrings[i]);\n\t\t\t\t//timeTextView.setText(timeString[0]);\n\t\t\t}\n\t\t}\n\t\t//将遍历之后的数组 arraylist的内容在选择器上显示 \n\t\talertDialog.setSingleChoiceItems(arrayList.toArray(new String[0]), 0, new DialogInterface.OnClickListener(){\n\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tdialog.dismiss();\n\t\t\t\tSystem.out.println(\"***被点击***\"+which);\n\t\t\t\tdialog.toString();\n\t\t\t\tswitch (which) {\n\t\t\t\tcase 0:\n\t\t\t\t\tarrivingTime = \"14:00-20:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"14:00:00\";\n\t\t\t\t\tpostArrivalLateTime = leaveTimeString + \" \" + \"20:00:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\t\t\n\t\t\t\tcase 1:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"20:00-23:59\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"20:00:00\";\n\t\t\t\t\tpostArrivalLateTime = leaveTimeString + \" \" + \"23:59:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\n\t\t\t\tcase 2:\t\t\t\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"23:59-次日06:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"23:59:00\";\n\t\t\t\t\tpostArrivalLateTime = getDateNext(liveTimeString) + \" \" + \"06:00:00\";\n\t\t\t\t\tint dayNum1 = Integer.parseInt(dayTextView.getText().toString());\n\t\t\t\t\tint roomNum1 = Integer.parseInt(roomtTextView.getText().toString());\n\t\t\t\t\tif(dayNum1 != 1){\n\t\t\t\t\t\t//dayTextView.setText(\"\"+(dayNum1+1));\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+((j/dayNum1)*(dayNum1+1)*roomNum1));\n\t\t\t\t\t}else{\n\t\t\t\t\t\t//dayTextView.setText(\"1\");\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+(j*1*roomNum1));\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\t\n\t\t\t\tdefault:\n\t\t\t\t\tarrivingTime = \"\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t}).show();\n\t}", "public void setPickerTime(@NonNull final LocalDateTime date) {\n onView(viewMatcher).perform(click());\n onView(withClassName(equalTo(TimePicker.class.getName())))\n .perform(PickerActions.setTime(date.getHour(), date.getMinute()));\n new Dialog().confirmDialog();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog18 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t18Hour18 = hourOfDay1;\n t18Minute18 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t18Hour18, t18Minute18);\n //set selected time on text view\n\n\n timeE9 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime9.setText(timeE9);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog18.updateTime(t18Hour18, t18Minute18);\n //show dialog\n timePickerDialog18.show();\n }", "private void showDateDialog() {\n\t\tDateDetailInfo[] dateInfo = DateDetailInfo.getDateDetailInfo();\n\t\tboolean noDate = (dateInfo == null);\n\t\tboolean allPermanent = (null != dateInfo)\n\t\t\t\t&& (dateInfo.length == 1)\n\t\t\t\t&& (dateInfo[0] != null)\n\t\t\t\t&& (dateInfo[0].deadText != null)\n\t\t\t\t&& (dateInfo[0].deadText.equals(this.getResources().getString(\n\t\t\t\t\t\tR.string.package_detail_forever)));\n\t\tif (DateDetailInfo.dayOffMax > 0 && (!(noDate || allPermanent))) {\n\t\t\tinitDateDialog();\n\t\t\tDateDialog dialog = new DateDialog(this);\n\t\t\tdialog.getWindow().setBackgroundDrawable(new ColorDrawable(0));\n\t\t\tdialog.requestWindowFeature(Window.FEATURE_NO_TITLE);\n\t\t\tdialog.setListener(new DialogInterface.OnClickListener() {\n\t\t\t\t@Override\n\t\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\t\tstartGetTicketActivity();\n\t\t\t\t}\n\t\t\t});\n\t\t\tif (null != DateDialog.mListStr && DateDialog.mListStr.length > 1) {\n\t\t\t\tdialog.show();\n\t\t\t}\n\t\t}\n\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog47 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t47Hour47 = hourOfDay1;\n t47Minute47 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t47Hour47, t47Minute47);\n //set selected time on text view\n\n\n timeS24 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime24.setText(timeS24);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog47.updateTime(t47Hour47, t47Minute47);\n //show dialog\n timePickerDialog47.show();\n }", "private void showTimerPickerDialog() {\n backupCal = cal;\n if (cal == null) {\n cal = Calendar.getInstance();\n }\n\n TimePickerFragment fragment = new TimePickerFragment();\n\n fragment.setCancelListener(new DialogInterface.OnCancelListener() {\n @Override\n public void onCancel(DialogInterface dialog) {\n cal = backupCal;\n EventBus.getDefault().post(new TaskEditedEvent());\n }\n });\n\n fragment.setCalendar(cal);\n fragment.show(getFragmentManager(), \"timePicker\");\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog43 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t43Hour43 = hourOfDay1;\n t43Minute43 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t43Hour43, t43Minute43);\n //set selected time on text view\n\n\n timeS22 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime22.setText(timeS22);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog43.updateTime(t43Hour43, t43Minute43);\n //show dialog\n timePickerDialog43.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog31 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t31Hour31 = hourOfDay1;\n t31Minute31 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t31Hour31, t31Minute31);\n //set selected time on text view\n\n\n timeS16 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime16.setText(timeS16);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog31.updateTime(t31Hour31, t31Minute31);\n //show dialog\n timePickerDialog31.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog48 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t48Hour48 = hourOfDay1;\n t48Minute48 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t48Hour48, t48Minute48);\n //set selected time on text view\n\n\n timeE24 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime24.setText(timeE24);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog48.updateTime(t48Hour48, t48Minute48);\n //show dialog\n timePickerDialog48.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog21 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t21Hour21 = hourOfDay1;\n t21Minute21 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t21Hour21, t21Minute21);\n //set selected time on text view\n\n\n timeS11 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime11.setText(timeS11);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog21.updateTime(t21Hour21, t21Minute21);\n //show dialog\n timePickerDialog21.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog16 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t16Hour16 = hourOfDay1;\n t16Minute16 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t16Hour16, t16Minute16);\n //set selected time on text view\n\n\n timeE8 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime8.setText(timeE8);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog16.updateTime(t16Hour16, t16Minute16);\n //show dialog\n timePickerDialog16.show();\n }", "private void getTimeView() {\n\n\t\ttry {\n\n\t\t\t// Launch Time Picker Dialog\n\n\t\t\tSystem.out.println(\"!!!!!in time picker\" + hour);\n\t\t\tSystem.out.println(\"!!!!!in time picker\" + minutes);\n\n\t\t\tTimePickerDialog tpd = new TimePickerDialog(this,\n\t\t\t\t\tnew TimePickerDialog.OnTimeSetListener() {\n\n\t\t\t\t\t\t@Override\n\t\t\t\t\t\tpublic void onTimeSet(TimePicker view, int hourOfDay,\n\t\t\t\t\t\t\t\tint minute) {\n\n\t\t\t\t\t\t\tif (rf_booking_date_box.getText().toString()\n\t\t\t\t\t\t\t\t\t.equalsIgnoreCase(currDate.toString())) {\n\t\t\t\t\t\t\t\tc = Calendar.getInstance();\n\t\t\t\t\t\t\t\tint curr_hour = c.get(Calendar.HOUR_OF_DAY);\n\t\t\t\t\t\t\t\tint curr_minutes = c.get(Calendar.MINUTE);\n\n\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!shikha\"\n\t\t\t\t\t\t\t\t\t\t\t\t+ curr_hour);\n\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!shikha\"\n\t\t\t\t\t\t\t\t\t\t\t\t+ curr_minutes);\n\n\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!hourOfDay<curr_hour\"\n\t\t\t\t\t\t\t\t\t\t\t\t+ (hourOfDay < curr_hour));\n\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!minute<curr_minutes\"\n\t\t\t\t\t\t\t\t\t\t\t\t+ (minute < curr_minutes));\n\n\t\t\t\t\t\t\t\tif (hourOfDay < curr_hour\n\t\t\t\t\t\t\t\t\t\t&& minute < curr_minutes\n\t\t\t\t\t\t\t\t\t\t|| hourOfDay < curr_hour\n\t\t\t\t\t\t\t\t\t\t&& minute <= curr_minutes\n\t\t\t\t\t\t\t\t\t\t|| hourOfDay == curr_hour\n\t\t\t\t\t\t\t\t\t\t&& minute < curr_minutes) {\n\t\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!!! in if\");\n\t\t\t\t\t\t\t\t\tToast.makeText(\n\t\t\t\t\t\t\t\t\t\t\tgetApplicationContext(),\n\t\t\t\t\t\t\t\t\t\t\tgetString(R.string.str_Please_choose_valid_time),\n\t\t\t\t\t\t\t\t\t\t\tToast.LENGTH_SHORT).show();\n\t\t\t\t\t\t\t\t} else {\n\n\t\t\t\t\t\t\t\t\tminutes = minute;\n\t\t\t\t\t\t\t\t\thour = hourOfDay;\n\n\t\t\t\t\t\t\t\t\tString time1 = hour + \":\" + minutes;\n\n\t\t\t\t\t\t\t\t\tDate time;\n\t\t\t\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\t\t\t\ttime = new SimpleDateFormat(\"HH:mm\")\n\t\t\t\t\t\t\t\t\t\t\t\t.parse(hour + \":\" + minutes);\n\n\t\t\t\t\t\t\t\t\t\tDateFormat outputFormatter = new SimpleDateFormat(\n\t\t\t\t\t\t\t\t\t\t\t\t\"HH:mm\");\n\t\t\t\t\t\t\t\t\t\tString final_time = outputFormatter\n\t\t\t\t\t\t\t\t\t\t\t\t.format(time);\n\n\t\t\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!final_time...\"\n\t\t\t\t\t\t\t\t\t\t\t\t\t\t+ final_time);\n\n\t\t\t\t\t\t\t\t\t\t// Display Selected time in textbox\n\t\t\t\t\t\t\t\t\t\trf_booking_time_box.setText(final_time);\n\t\t\t\t\t\t\t\t\t\tBooking_Screen_TabLayout.rf_booking_time_header.setText(final_time);\n\n\t\t\t\t\t\t\t\t\t\t// Display Selected time in textbox\n\t\t\t\t\t\t\t\t\t\t// rf_booking_time_box.setText(hourOfDay\n\t\t\t\t\t\t\t\t\t\t// + \":\" +\n\t\t\t\t\t\t\t\t\t\t// minute);\n\t\t\t\t\t\t\t\t\t\tGlobal_variable.str_Time_From = final_time;\n\t\t\t\t\t\t\t\t\t\tGlobal_variable.str_Time_To = final_time;\n\n\t\t\t\t\t\t\t\t\t} catch (java.text.ParseException e) {\n\t\t\t\t\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t\t} else {\n\n\t\t\t\t\t\t\t\tminutes = minute;\n\t\t\t\t\t\t\t\thour = hourOfDay;\n\n\t\t\t\t\t\t\t\tString time1 = hour + \":\" + minutes;\n\n\t\t\t\t\t\t\t\tDate time;\n\t\t\t\t\t\t\t\ttry {\n\t\t\t\t\t\t\t\t\ttime = new SimpleDateFormat(\"HH:mm\")\n\t\t\t\t\t\t\t\t\t\t\t.parse(hour + \":\" + minutes);\n\n\t\t\t\t\t\t\t\t\tDateFormat outputFormatter = new SimpleDateFormat(\n\t\t\t\t\t\t\t\t\t\t\t\"HH:mm\");\n\t\t\t\t\t\t\t\t\tString final_time = outputFormatter\n\t\t\t\t\t\t\t\t\t\t\t.format(time);\n\n\t\t\t\t\t\t\t\t\tSystem.out\n\t\t\t\t\t\t\t\t\t\t\t.println(\"!!!!!!!!!!!!!!!!!final_time...\"\n\t\t\t\t\t\t\t\t\t\t\t\t\t+ final_time);\n\n\t\t\t\t\t\t\t\t\t// Display Selected time in textbox\n\t\t\t\t\t\t\t\t\trf_booking_time_box.setText(final_time);\n\t\t\t\t\t\t\t\t\tBooking_Screen_TabLayout.rf_booking_time_header.setText(final_time);\n\t\t\t\t\t\t\t\t\t// Display Selected time in textbox\n\t\t\t\t\t\t\t\t\t// rf_booking_time_box.setText(hourOfDay +\n\t\t\t\t\t\t\t\t\t// \":\" +\n\t\t\t\t\t\t\t\t\t// minute);\n\t\t\t\t\t\t\t\t\tGlobal_variable.str_Time_From = final_time;\n\t\t\t\t\t\t\t\t\tGlobal_variable.str_Time_To = final_time;\n\n\t\t\t\t\t\t\t\t} catch (java.text.ParseException e) {\n\t\t\t\t\t\t\t\t\t// TODO Auto-generated catch block\n\t\t\t\t\t\t\t\t\te.printStackTrace();\n\t\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t}\n\t\t\t\t\t}, hour, minutes, false);\n\t\t\ttpd.show();\n\t\t\ttpd.setCancelable(false);\n\t\t\ttpd.setCanceledOnTouchOutside(false);\n\n\t\t} catch (NullPointerException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog13 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t13Hour13 = hourOfDay1;\n t13Minute13 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t13Hour13, t13Minute13);\n //set selected time on text view\n\n\n timeS7 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime7.setText(timeS7);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog13.updateTime(t13Hour13, t13Minute13);\n //show dialog\n timePickerDialog13.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog19 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t19Hour19 = hourOfDay1;\n t19Minute19 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t19Hour19, t19Minute19);\n //set selected time on text view\n\n\n timeS10 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime10.setText(timeS10);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog19.updateTime(t19Hour19, t19Minute19);\n //show dialog\n timePickerDialog19.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog41 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t41Hour41 = hourOfDay1;\n t41Minute41 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t41Hour41, t41Minute41);\n //set selected time on text view\n\n\n timeS21 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime21.setText(timeS21);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog41.updateTime(t41Hour41, t41Minute41);\n //show dialog\n timePickerDialog41.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog50 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t50Hour50 = hourOfDay1;\n t50Minute50 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t50Hour50, t50Minute50);\n //set selected time on text view\n\n\n timeE25 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime25.setText(timeE25);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog50.updateTime(t50Hour50, t50Minute50);\n //show dialog\n timePickerDialog50.show();\n }", "private void customTime(boolean shouldStart) {\n\n if (customCalendar == null) {\n customCalendar = Calendar.getInstance();\n customYear = customCalendar.get(Calendar.YEAR);\n customMonth = customCalendar.get(Calendar.MONTH);\n customDay = customCalendar.get(Calendar.DAY_OF_MONTH);\n }\n\n timeDialog = new DatePickerDialog(this, this, customYear, customMonth, customDay);\n timeDialog.show();\n if (shouldStart) {\n Toasty.info(StatActivity.this, \"Selection start time\").show();\n } else {\n Toasty.info(StatActivity.this, \"Select end time\").show();\n }\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog46 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t46Hour46 = hourOfDay1;\n t46Minute46 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t46Hour46, t46Minute46);\n //set selected time on text view\n\n\n timeE23 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime23.setText(timeE23);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog46.updateTime(t46Hour46, t46Minute46);\n //show dialog\n timePickerDialog46.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog10 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t10Hour10 = hourOfDay1;\n t10Minute10 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t10Hour10, t10Minute10);\n //set selected time on text view\n\n\n timeE5 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime5.setText(timeE5);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog10.updateTime(t10Hour10, t10Minute10);\n //show dialog\n timePickerDialog10.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog27 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t27Hour27 = hourOfDay1;\n t27Minute27 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t27Hour27, t27Minute27);\n //set selected time on text view\n\n\n timeS14 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime14.setText(timeS14);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog27.updateTime(t27Hour27, t27Minute27);\n //show dialog\n timePickerDialog27.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog4 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t4Hour4 = hourOfDay1;\n t4Minute4 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t4Hour4, t4Minute4);\n //set selected time on text view\n\n\n timeE2 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime2.setText(timeE2);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog4.updateTime(t4Hour4, t4Minute4);\n //show dialog\n timePickerDialog4.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog36 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t36Hour36 = hourOfDay1;\n t36Minute36 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t36Hour36, t36Minute36);\n //set selected time on text view\n\n\n timeE18 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime18.setText(timeE18);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog36.updateTime(t36Hour36, t36Minute36);\n //show dialog\n timePickerDialog36.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog23 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t23Hour23 = hourOfDay1;\n t23Minute23 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t23Hour23, t23Minute23);\n //set selected time on text view\n\n\n timeS12 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime12.setText(timeS12);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog23.updateTime(t23Hour23, t23Minute23);\n //show dialog\n timePickerDialog23.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog12 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t12Hour12 = hourOfDay1;\n t12Minute12 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t12Hour12, t12Minute12);\n //set selected time on text view\n\n\n timeE6 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime6.setText(timeE6);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog12.updateTime(t12Hour12, t12Minute12);\n //show dialog\n timePickerDialog12.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog34 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t34Hour34 = hourOfDay1;\n t34Minute34 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t34Hour34, t34Minute34);\n //set selected time on text view\n\n\n timeE17 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime17.setText(timeE17);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog34.updateTime(t34Hour34, t34Minute34);\n //show dialog\n timePickerDialog34.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog45 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t45Hour45 = hourOfDay1;\n t45Minute45 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t45Hour45, t45Minute45);\n //set selected time on text view\n\n\n timeS23 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime23.setText(timeS23);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog45.updateTime(t45Hour45, t45Minute45);\n //show dialog\n timePickerDialog45.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog38 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t38Hour38 = hourOfDay1;\n t38Minute38 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t38Hour38, t38Minute38);\n //set selected time on text view\n\n\n timeE19 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime19.setText(timeE19);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog38.updateTime(t38Hour38, t38Minute38);\n //show dialog\n timePickerDialog38.show();\n }", "private void showChooseCurNonGarTimeDialog1(){\n\t\talertDialog = new AlertDialog.Builder(this);\n\t\talertDialog.setTitle(\"请选择添到店时间\");\n\t\ttimeString = new String[] { \"20:00\", \"23:59\",\"次日06:00\"};\n\t\tfinal ArrayList<String> arrayList = new ArrayList<String>();\n\t\t//final ArrayList<String> arrayListType = new ArrayList<String>();\n\n\t\tfor (int i = 0; i < timeString.length; i++) {\n\t\t\tif (!timeString[i].equals(\"null\")) {\n\t\t\t\tarrayList.add(timeString[i]);\t\n\t\t\t\t//arrayListType.add(typeArrayStrings[i]);\n\n\t\t\t}\n\t\t}\n\t\t//将遍历之后的数组 arraylist的内容在选择器上显示 \n\t\talertDialog.setSingleChoiceItems(arrayList.toArray(new String[0]), 0, new DialogInterface.OnClickListener(){\n\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tdialog.dismiss();\n\t\t\t\tSystem.out.println(\"***被点击***\"+which);\n\t\t\t\tdialog.toString();\n\t\t\t\tswitch (which) {\n\t\t\t\tcase 0:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = (getTimeCurrentHr()+1)+\":00\"+\"-\"+\"20:00\";\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" + (getTimeCurrentHr()+1)+\":00:00\";\n\t\t\t\t\tpostArrivalLateTime = leaveTimeString + \" \" + \"20:00:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\t\t\n\t\t\t\tcase 1:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"20:00-23:59\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"20:00:00\";\n\t\t\t\t\tpostArrivalLateTime = leaveTimeString + \" \" + \"23:59:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\t\t\t\n\t\t\t\tcase 2:\t\t\t\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"23:59-次日06:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"23:59:00\";\n\t\t\t\t\tpostArrivalLateTime = getDateNext(liveTimeString) + \" \" + \"06:00:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tint dayNum1 = Integer.parseInt(dayTextView.getText().toString());\n\t\t\t\t\tint roomNum1 = Integer.parseInt(roomtTextView.getText().toString());\n\t\t\t\t\tif(dayNum1 != 1){\n\t\t\t\t\t\t//dayTextView.setText(\"\"+(dayNum1+1));\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+((j/dayNum1)*(dayNum1-1)*roomNum1));\n\t\t\t\t\t}else{\n\t\t\t\t\t\t//dayTextView.setText(\"1\");\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+(j*1*roomNum1));\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t\tbreak;\t\t\t\t\n\t\t\t\tdefault:\n\t\t\t\t\tarrivingTime = \"\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t}).show();\n\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog35 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t35Hour35 = hourOfDay1;\n t35Minute35 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t35Hour35, t35Minute35);\n //set selected time on text view\n\n\n timeS18 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime18.setText(timeS18);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog35.updateTime(t35Hour35, t35Minute35);\n //show dialog\n timePickerDialog35.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog32 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t32Hour32 = hourOfDay1;\n t32Minute32 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t32Hour32, t32Minute32);\n //set selected time on text view\n\n\n timeE16 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime16.setText(timeE16);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog32.updateTime(t32Hour32, t32Minute32);\n //show dialog\n timePickerDialog32.show();\n }", "@Override\n public void onClick(View v) {\n Calendar mcurrentTime = Calendar.getInstance();\n int hour = mcurrentTime.get(Calendar.HOUR_OF_DAY);\n int minute = mcurrentTime.get(Calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(AddReminder.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n edtSelectTimeForMeet.setText( \"\" + selectedHour + \":\" + selectedMinute);\n }\n }, hour, minute, true);\n mTimePicker.setTitle(\"Select Time\");\n mTimePicker.show();\n\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog14 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t14Hour14 = hourOfDay1;\n t14Minute14 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t14Hour14, t14Minute14);\n //set selected time on text view\n\n\n timeE7 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime7.setText(timeE7);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog14.updateTime(t14Hour14, t14Minute14);\n //show dialog\n timePickerDialog14.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog17 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t17Hour17 = hourOfDay1;\n t17Minute17 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t17Hour17, t17Minute17);\n //set selected time on text view\n\n\n timeS9 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime9.setText(timeS9);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog17.updateTime(t17Hour17, t17Minute17);\n //show dialog\n timePickerDialog17.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog37 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t37Hour37 = hourOfDay1;\n t37Minute37 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t37Hour37, t37Minute37);\n //set selected time on text view\n\n\n timeS19 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime19.setText(timeS19);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog37.updateTime(t37Hour37, t37Minute37);\n //show dialog\n timePickerDialog37.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog24 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t24Hour24 = hourOfDay1;\n t24Minute24 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t24Hour24, t24Minute24);\n //set selected time on text view\n\n\n timeE12 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime12.setText(timeE12);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog24.updateTime(t24Hour24, t24Minute24);\n //show dialog\n timePickerDialog24.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog22 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t22Hour22 = hourOfDay1;\n t22Minute22 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t22Hour22, t22Minute22);\n //set selected time on text view\n\n\n timeE11 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime11.setText(timeE11);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog22.updateTime(t22Hour22, t22Minute22);\n //show dialog\n timePickerDialog22.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog26 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t26Hour26 = hourOfDay1;\n t26Minute26 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t26Hour26, t26Minute26);\n //set selected time on text view\n\n\n timeE13 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime13.setText(timeE13);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog26.updateTime(t26Hour26, t26Minute26);\n //show dialog\n timePickerDialog26.show();\n }", "@Override\n public void onClick(View view) {\n timeDialog.show(getFragmentManager(), \"timePicker\");\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog28 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t28Hour28 = hourOfDay1;\n t28Minute28 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t28Hour28, t28Minute28);\n //set selected time on text view\n\n\n timeE14 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime14.setText(timeE14);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog28.updateTime(t28Hour28, t28Minute28);\n //show dialog\n timePickerDialog28.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog49 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t49Hour49 = hourOfDay1;\n t49Minute49 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t49Hour49, t49Minute49);\n //set selected time on text view\n\n\n timeS25 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime25.setText(timeS25);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog49.updateTime(t49Hour49, t49Minute49);\n //show dialog\n timePickerDialog49.show();\n }", "public void showDateTimePickerDialog(final EditText view) {\n final Dialog dialog = new Dialog(getActivity());\n dialog.setContentView(R.layout.dialog_viewing_time);\n dialog.setTitle(\"Select Viewing Date\");\n final StringBuilder selectedDateTime = new StringBuilder();\n final DatePicker datePicker = (DatePicker) dialog.findViewById(R.id.datePicker);\n\n Button selectDateTimeButton = (Button) dialog.findViewById(R.id.selectDateTimeButton);\n\n selectDateTimeButton.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n selectedDateTime.append(datePicker.getDayOfMonth())\n .append(ApplicationConstants.DATE_SEPERATOR)\n .append(datePicker.getMonth() + 1)\n .append(ApplicationConstants.DATE_SEPERATOR)\n .append(datePicker.getYear());\n view.setText(selectedDateTime.toString());\n dialog.dismiss();\n }\n });\n\n dialog.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog2 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t2Hour2 = hourOfDay1;\n t2Minute2 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t2Hour2, t2Minute2);\n //set selected time on text view\n\n\n timeE1 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime1.setText(timeE1);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog2.updateTime(t2Hour2, t2Minute2);\n //show dialog\n timePickerDialog2.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog33 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t33Hour33 = hourOfDay1;\n t33Minute33 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t33Hour33, t33Minute33);\n //set selected time on text view\n\n\n timeS17 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime17.setText(timeS17);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog33.updateTime(t33Hour33, t33Minute33);\n //show dialog\n timePickerDialog33.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog29 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t29Hour29 = hourOfDay1;\n t29Minute29 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t29Hour29, t29Minute29);\n //set selected time on text view\n\n\n timeS15 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime15.setText(timeS15);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog29.updateTime(t29Hour29, t29Minute29);\n //show dialog\n timePickerDialog29.show();\n }", "public void pickTime(View view) {\n\n DialogFragment newFragment = new TimePicker();\n newFragment.show(getFragmentManager(), \"timePicker\");\n\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog25 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t25Hour25 = hourOfDay1;\n t25Minute25 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t25Hour25, t25Minute25);\n //set selected time on text view\n\n\n timeS13 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime13.setText(timeS13);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog25.updateTime(t25Hour25, t25Minute25);\n //show dialog\n timePickerDialog25.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog8 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t8Hour8 = hourOfDay1;\n t8Minute8 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t8Hour8, t8Minute8);\n //set selected time on text view\n\n\n timeE4 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime4.setText(timeE4);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog8.updateTime(t8Hour8, t8Minute8);\n //show dialog\n timePickerDialog8.show();\n }", "@Override\n\t\t\tpublic void onClick(View arg0) {\n\t\t\t\tshowDialog(SET_DATE_DIALOG);\n\n\t\t\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog11 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t11Hour11 = hourOfDay1;\n t11Minute11 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t11Hour11, t11Minute11);\n //set selected time on text view\n\n\n timeS6 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime6.setText(timeS6);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog11.updateTime(t11Hour11, t11Minute11);\n //show dialog\n timePickerDialog11.show();\n }", "public void initializeTime() {\n hour = cal.get(Calendar.HOUR);\n min = cal.get(Calendar.MINUTE);\n\n time = (EditText) findViewById(R.id.textSetTime);\n time.setInputType(InputType.TYPE_NULL);\n\n //Set EditText text to be current time\n if(min < 10) {\n time.setText(hour + \":0\" + min);\n } else {\n time.setText(hour + \":\" + min);\n }\n\n time.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n picker = new TimePickerDialog(ControlCenterActivity.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int i, int i1) {\n if(i1 < 10) {\n time.setText(i + \":0\" + i1);\n } else {\n time.setText(i + \":\" + i1);\n }\n }\n }, hour, min, false);\n\n picker.show();\n }\n });\n }", "@Override\n public void onDateSet(DatePicker view, int selectedYear,\n int selectedMonth, int selectedDay) {\n\n year = selectedYear;\n month = selectedMonth;\n day = selectedDay;\n\n showDialog(AppUtils.TIME_DIALOG_ID);\n\n }", "@Override\n public void onClick(View v) {\n int hour = calendar.get(calendar.HOUR_OF_DAY);\n int minute = calendar.get(calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(getContext(), new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n String time = (selectedHour > 9 ? selectedHour : \"0\" + selectedHour)\n + \":\" +\n (selectedMinute > 9 ? selectedMinute : \"0\" + selectedMinute);\n Date horaPlantaTime;\n Date horaMuestroTime;\n Date horaCamionTime;\n\n try {\n if (globals.getAntecedentesHormigonMuestreo().getPlantaOut() == null) {\n Toast.makeText(getContext(), \"No se ha definido hora de salida planta\", Toast.LENGTH_SHORT).show();\n timeCamion.setText(\"\");\n } else {\n horaPlantaTime = parser.parse(globals.getAntecedentesHormigonMuestreo().getPlantaOut());\n\n horaCamionTime = parser.parse(time);\n if (horaCamionTime.after(horaPlantaTime)) {\n\n timeCamion.setText(time);\n globals.getAntecedentesMuestreo().setTimeCamion(time);\n } else {\n Toast.makeText(getContext(), \"Hora llegada camióm no puede ser inferior a la hora de salida planta\", Toast.LENGTH_SHORT).show();\n timeCamion.setText(\"\");\n }\n }\n } catch (ParseException e) {\n timeCamion.setText(\"\");\n }\n\n try {\n if (globals.getAntecedentesMuestreo().getTimeMuestreo() == null) {\n Toast.makeText(getContext(), \"No se ha definido hora de muestreo\", Toast.LENGTH_SHORT).show();\n timeCamion.setText(\"\");\n } else {\n horaMuestroTime = parser.parse(globals.getAntecedentesMuestreo().getTimeMuestreo());\n\n horaCamionTime = parser.parse(time);\n if (horaCamionTime.before(horaMuestroTime)) {\n\n timeCamion.setText(time);\n globals.getAntecedentesMuestreo().setTimeCamion(time);\n } else {\n Toast.makeText(getContext(), \"Hora llegada camióm no puede ser mayor a la hora de toma muestra\", Toast.LENGTH_SHORT).show();\n timeCamion.setText(\"\");\n }\n }\n } catch (ParseException e) {\n timeCamion.setText(\"\");\n }\n\n }\n }, hour, minute, true);\n mTimePicker.setTitle(\"Seleccione Hora\");\n mTimePicker.show();\n\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog9 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t9Hour9 = hourOfDay1;\n t9Minute9 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t9Hour9, t9Minute9);\n //set selected time on text view\n\n\n timeS5 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime5.setText(timeS5);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog9.updateTime(t9Hour9, t9Minute9);\n //show dialog\n timePickerDialog9.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog1 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t1Hour1 = hourOfDay1;\n t1Minute1 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t1Hour1, t1Minute1);\n //set selected time on text view\n\n\n timeS1 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime1.setText(timeS1);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog1.updateTime(t1Hour1, t1Minute1);\n //show dialog\n timePickerDialog1.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog3 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t3Hour3 = hourOfDay1;\n t3Minute3 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t3Hour3, t3Minute3);\n //set selected time on text view\n\n\n timeS2 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime2.setText(timeS2);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog3.updateTime(t3Hour3, t3Minute3);\n //show dialog\n timePickerDialog3.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog44 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t44Hour44 = hourOfDay1;\n t44Minute44 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t44Hour44, t44Minute44);\n //set selected time on text view\n\n\n timeE22 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime22.setText(timeE22);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog44.updateTime(t44Hour44, t44Minute44);\n //show dialog\n timePickerDialog44.show();\n }", "public void actionPerformed(ActionEvent e) {\n\t\t\t\tif (textField.getText().isEmpty() || textField_1.getText().isEmpty() || textField_2.getText().isEmpty()\r\n\t\t\t\t\t\t|| textField_3.getText().isEmpty() || textField_5.getText().isEmpty()) {\r\n\r\n\t\t\t\t\tJOptionPane.showMessageDialog(null, \"Please fill all the blanks to set the time\", \"Warning!\",\r\n\t\t\t\t\t\t\tJOptionPane.WARNING_MESSAGE);\r\n\t\t\t\t}\r\n\t\t\t\t// time components must be in proper way\r\n\t\t\t\telse if (Integer.parseInt(textField.getText()) > 31 || Integer.parseInt(textField.getText()) <= 0\r\n\t\t\t\t\t\t|| Integer.parseInt(textField_1.getText()) > 23 || Integer.parseInt(textField_1.getText()) < 0\r\n\t\t\t\t\t\t|| Integer.parseInt(textField_3.getText()) > 59 || Integer.parseInt(textField_3.getText()) < 0\r\n\t\t\t\t\t\t|| Integer.parseInt(textField_2.getText()) > 12\r\n\t\t\t\t\t\t|| Integer.parseInt(textField_2.getText()) <= 0) {\r\n\r\n\t\t\t\t\tJOptionPane.showMessageDialog(null, \"Please enter a valid date\", \"Warning!\",\r\n\t\t\t\t\t\t\tJOptionPane.WARNING_MESSAGE);\r\n\r\n\t\t\t\t}\r\n\t\t\t\t// if everything works perfectly, the values will be parsed to integer and\r\n\t\t\t\t// copied to respective variables\r\n\t\t\t\telse {\r\n\t\t\t\t\tminute = Integer.parseInt(textField_3.getText());\r\n\t\t\t\t\thour = Integer.parseInt(textField_1.getText());\r\n\t\t\t\t\tday = Integer.parseInt(textField.getText());\r\n\t\t\t\t\tmonth = Integer.parseInt(textField_2.getText()) - 1;\r\n\t\t\t\t\tyear = Integer.parseInt(textField_5.getText());\r\n\r\n\t\t\t\t\t// cal is the object of Calendar class, here the time components are set to the\r\n\t\t\t\t\t// object and it will be displayed on the frame.\r\n\t\t\t\t\t// String.format is used in order to display the time in proper way\r\n\t\t\t\t\tcal.set(year, month, day, hour, minute);\r\n\t\t\t\t\tsysTime.setText(String.format(\"%02d\", cal.get(Calendar.HOUR_OF_DAY)) + \":\"\r\n\t\t\t\t\t\t\t+ String.format(\"%02d\", cal.get(Calendar.MINUTE)));\r\n\t\t\t\t\tsysDate.setText(String.format(\"%02d\", cal.get(Calendar.DAY_OF_MONTH)) + \"/\"\r\n\t\t\t\t\t\t\t+ String.format(\"%02d\", (cal.get(Calendar.MONTH) + 1)) + \"/\"\r\n\t\t\t\t\t\t\t+ String.format(\"%02d\", cal.get(Calendar.YEAR)));\r\n\t\t\t\t\tsysWeekday.setText(cal.getDisplayName(Calendar.DAY_OF_WEEK, Calendar.LONG, Locale.ENGLISH));\r\n\t\t\t\t}\r\n\t\t\t}", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog30 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t30Hour30 = hourOfDay1;\n t30Minute30 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t30Hour30, t30Minute30);\n //set selected time on text view\n\n\n timeE15 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime15.setText(timeE15);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog30.updateTime(t30Hour30, t30Minute30);\n //show dialog\n timePickerDialog30.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog5 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t5Hour5 = hourOfDay1;\n t5Minute5 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t5Hour5, t5Minute5);\n //set selected time on text view\n\n\n timeS3 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime3.setText(timeS3);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog5.updateTime(t5Hour5, t5Minute5);\n //show dialog\n timePickerDialog5.show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog15 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t15Hour15 = hourOfDay1;\n t15Minute15 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t15Hour15, t15Minute15);\n //set selected time on text view\n\n\n timeS8 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime8.setText(timeS8);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog15.updateTime(t15Hour15, t15Minute15);\n //show dialog\n timePickerDialog15.show();\n }", "private void showDateDialog(){\n final Calendar newCalendar = Calendar.getInstance();\n\n /**\n * Initiate DatePicker dialog\n */\n datePickerDialog = new DatePickerDialog(this, new DatePickerDialog.OnDateSetListener() {\n\n @Override\n public void onDateSet(DatePicker view, int year, int monthOfYear, int dayOfMonth) {\n\n /**\n * Method ini dipanggil saat kita selesai memilih tanggal di DatePicker\n */\n\n /**\n * Set Calendar untuk menampung tanggal yang dipilih\n */\n Calendar newDate = Calendar.getInstance();\n newDate.set(year, monthOfYear, dayOfMonth);\n\n\n if(!newDate.before(newCalendar)){\n /**\n * Update TextView with choosen date\n */\n newDate.set(Calendar.HOUR_OF_DAY, 0);\n newDate.set(Calendar.MINUTE, 0);\n newDate.set(Calendar.SECOND, 0);\n newDate.set(Calendar.MILLISECOND,0);\n mDateTextView.setTextColor(Color.BLACK);\n String day = mDateFormatter.getDayName(newDate.getTime());\n String date = mDateFormatter.getOnlyDate(newDate.getTime());\n String month = mDateFormatter.getMonth(newDate.getTime());\n mDateTextView.setText(day + \" \" + date + \",\" + month);\n mChoosenSaveDate = newDate;\n }else{\n mDateTextView.setText(\"Deadline has to be at leats same as current date\");\n mDateTextView.setTextColor(Color.RED);\n Toast.makeText(view.getContext(),\"invalid choosen date\",\n Toast.LENGTH_LONG).show();\n }\n\n\n }\n\n },newCalendar.get(Calendar.YEAR), newCalendar.get(Calendar.MONTH), newCalendar.get(Calendar.DAY_OF_MONTH));\n\n /**\n * Tampilkan DatePicker dialog\n */\n datePickerDialog.show();\n\n }", "public void setupTimeDialog(PlaceIt placeit) {\n\t\t\n\t\tAlertDialog.Builder builder = new AlertDialog.Builder(this);\n\t\tbuilder.setTitle(\"Set recurrence for PlaceIt \" + placeit.getTitle());\n\t\tLayoutInflater inflater = getLayoutInflater();\n\t\tfinal View dialog = inflater.inflate(R.layout.placeit_time_form, null);\n\t\t\n\t\tint checkedItem = -1;\n\t\t\n\t\t// Create single choice list\n\t\tbuilder.setSingleChoiceItems(R.array.days_array, checkedItem, new DialogInterface.OnClickListener() {\n\t\t\t@Override\n public void onClick(DialogInterface dialog, int checkedItem) {\n\t\t\t\t// do something with checkedItem\n }\n\t\t});\n\t\t// Create textbox for number of weeks\n\t\tTextView every = (TextView) dialog.findViewById(R.id.every);\n\t\tfinal EditText numweeks = (EditText) dialog.findViewById(R.id.numweeks);\n\t\tTextView weeks = (TextView) dialog.findViewById(R.id.weeks);\n\t\t\n\t\t\n\t\t// Set the action buttons\n builder.setPositiveButton(R.string.recurrence_ok, new DialogInterface.OnClickListener() {\n @Override\n public void onClick(DialogInterface dialog, int id) {\n // User clicked OK, so save the mSelectedItems results somewhere\n // or return them to the component that opened the dialog\n \n }\n });\n builder.setNegativeButton(R.string.recurrence_cancel, new DialogInterface.OnClickListener() {\n @Override\n public void onClick(DialogInterface dialog, int id) {\n \n }\n });\n\t\t\n builder.setView(dialog);\n builder.show();\n\t\t\n\t\t/*\n\t\tSpinner dayspinner = (Spinner) findViewById(R.id.days_spinner);\n\t\t\n\t\t// Create an ArrayAdapter using the string array and a default spinner layout\n\t\tArrayAdapter<CharSequence> adapter = ArrayAdapter.createFromResource(this,\n\t\t R.array.days_array, android.R.layout.simple_spinner_item);\n\t\t// Specify the layout to use when the list of choices appears\n\t\tadapter.setDropDownViewResource(android.R.layout.simple_spinner_dropdown_item);\n\t\t// Apply the adapter to the spinner\n\t\tdayspinner.setAdapter(adapter);\n\t\t\n\t\t\n\t\talert.setView(dialog);\n\t\talert.show();\n\t\t*/\n\t\t\n\t}", "@Override\n\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\ttimeSet.performClick();\n\t\t\t\tif(ifFO.equals(\"Time_On\")){\n\t\t\t\t\tAppConstants.open.getTime();\n\t\t\t\t}else{\n\t\t\t\t\tAppConstants.close.getTime();\n\t\t\t\t}\n\t\t\t}", "private void showChooseCurNonGarTimeDialog3(){\n\t\talertDialog = new AlertDialog.Builder(this);\n\t\talertDialog.setTitle(\"请选择添到店时间\");\n\t\ttimeString = new String[] {\"次日06:00\"};\n\t\tfinal ArrayList<String> arrayList = new ArrayList<String>();\n\t\t//final ArrayList<String> arrayListType = new ArrayList<String>();\n\n\t\tfor (int i = 0; i < timeString.length; i++) {\n\t\t\tif (!timeString[i].equals(\"null\")) {\n\t\t\t\tarrayList.add(timeString[i]);\t\n\t\t\t\t//arrayListType.add(typeArrayStrings[i]);\n\n\t\t\t}\n\t\t}\n\t\t//将遍历之后的数组 arraylist的内容在选择器上显示 \n\t\talertDialog.setSingleChoiceItems(arrayList.toArray(new String[0]), 0, new DialogInterface.OnClickListener(){\n\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface dialog, int which) {\n\t\t\t\t// TODO Auto-generated method stub\n\t\t\t\tdialog.dismiss();\n\t\t\t\tSystem.out.println(\"***被点击***\"+which);\n\t\t\t\tdialog.toString();\n\t\t\t\tswitch (which) {\n\t\t\t\tcase 0:\n\t\t\t\t\t\n\t\t\t\t\tarrivingTime = \"23:59-次日06:00\";\n\t\t\t\t\ttimeTextView.setText(arrivingTime);\n\t\t\t\t\tpostArrivalEarlyTime = liveTimeString + \" \" +\"23:59:00\";\n\t\t\t\t\tpostArrivalLateTime = getDateNext(liveTimeString) + \" \" + \"06:00:00\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tint dayNum1 = Integer.parseInt(dayTextView.getText().toString());\n\t\t\t\t\tint roomNum1 = Integer.parseInt(roomtTextView.getText().toString());\n\t\t\t\t\tif(dayNum1 != 1){\n\t\t\t\t\t\t//dayTextView.setText(\"\"+(dayNum1+1));\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+((j/dayNum1)*(dayNum1-1)*roomNum1));\n\t\t\t\t\t}else{\n\t\t\t\t\t\t//dayTextView.setText(\"1\");\n\t\t\t\t\t\t//zongpicTextView.setText(\"¥\"+(j*1*roomNum1));\n\t\t\t\t\t}\n\t\t\t\t\tbreak;\t\t\t\t\t\n\t\t\t\n\t\t\t\tdefault:\n\t\t\t\t\tarrivingTime = \"\";\n\t\t\t\t\tsetTime(arrivingTime);\n\t\t\t\t\tbreak;\n\t\t\t\t}\n\t\t\t}\n\t\t\t\n\t\t}).show();\n\t}", "@Override\n public void onClick(View v) {\n int hour = calendar.get(calendar.HOUR_OF_DAY);\n int minute = calendar.get(calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(getContext(), new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n String time = (selectedHour > 9 ? selectedHour : \"0\" + selectedHour)\n + \":\" +\n (selectedMinute > 9 ? selectedMinute : \"0\" + selectedMinute);\n\n Date horaInTime;\n Date horaMuestreoTime;\n try {\n if (globals.getMuestra().getHoraIn() == null) {\n Toast.makeText(getContext(), \"No se ha definido hora de llegada\", Toast.LENGTH_SHORT).show();\n timeMuestreo.setText(\"\");\n } else {\n horaInTime = parser.parse(globals.getMuestra().getHoraIn());\n horaMuestreoTime = parser.parse(time);\n if (horaMuestreoTime.after(horaInTime)) {\n\n timeMuestreo.setText(time);\n globals.getAntecedentesMuestreo().setTimeMuestreo(time);\n } else {\n Toast.makeText(getContext(), \"Hora de Muestreo no puede ser inferior a la hora de llegada\", Toast.LENGTH_SHORT).show();\n timeMuestreo.setText(\"\");\n }\n }\n } catch (ParseException e) {\n timeMuestreo.setText(\"\");\n }\n }\n }, hour, minute, true);\n mTimePicker.setTitle(\"Seleccione Hora\");\n mTimePicker.show();\n\n }", "private void showDateStampOptionDialog() {\n\t\t// TODO Auto-generated method stub\n\t\tCharSequence title = res.getString(R.string.setting_datestamp);\n\t\tfinal String[] dateStampUIString = uiDisplayResource\n\t\t\t\t.getDateStampUIString();\n\t\tif (dateStampUIString == null) {\n\t\t\tWriteLogToDevice.writeLog(\"[Error] -- SettingView: \",\n\t\t\t\t\t\"dateStampUIString == null\");\n\t\t\treturn;\n\t\t}\n\t\tint length = dateStampUIString.length;\n\n\t\tint curIdx = 0;\n\t\tUIInfo uiInfo = reflection.refecltFromSDKToUI(\n\t\t\t\tSDKReflectToUI.SETTING_UI_DATE_STAMP,\n\t\t\t\tcameraProperties.getCurrentDateStamp());\n\t\tfor (int i = 0; i < length; i++) {\n\t\t\tif (dateStampUIString[i].equals(uiInfo.uiStringInSetting)) {\n\t\t\t\tcurIdx = i;\n\t\t\t}\n\t\t}\n\n\t\tDialogInterface.OnClickListener listener = new DialogInterface.OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(DialogInterface arg0, int arg1) {\n\t\t\t\tint value = (Integer) reflection.refecltFromUItoSDK(\n\t\t\t\t\t\tUIReflectToSDK.SETTING_SDK_DATE_STAMP,\n\t\t\t\t\t\tdateStampUIString[arg1]);\n\t\t\t\tLog.d(\"tigertiger\", \"----------------value =\" + value);\n\t\t\t\tcameraProperties.setDateStamp(value);\n\t\t\t\targ0.dismiss();\n\t\t\t\tsettingValueList = getSettingValue();\n\t\t\t\tif (optionListAdapter == null) {\n\t\t\t\t\treturn;\n\t\t\t\t}\n\t\t\t\toptionListAdapter.notifyDataSetChanged();\n\t\t\t}\n\t\t};\n\t\tshowOptionDialog(title, dateStampUIString, curIdx, listener, true);\n\t}", "@Override\n public void onClick(View v) {\n new DatePickerDialog(MainActivity.this, date, myCalendar\n .get(Calendar.YEAR), myCalendar.get(Calendar.MONTH),\n myCalendar.get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\r\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tshowDialog(DATE_DIALOG_ID);\r\n\t\t\t}", "private void showSecondINputDialog() {\n String currentDateTimeString = DateFormat.getDateTimeInstance().format(new Date());\n Toast.makeText(this, currentDateTimeString,\n Toast.LENGTH_LONG).show();\n }", "@Override\n public void onClick(View v) {\n int hour = calendar.get(calendar.HOUR_OF_DAY);\n int minute = calendar.get(calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(getContext(), new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n String time = (selectedHour > 9 ? selectedHour : \"0\" + selectedHour)\n + \":\" +\n (selectedMinute > 9 ? selectedMinute : \"0\" + selectedMinute);\n Date horaCamionTime;\n Date horaMuestreoTime;\n Date horaDescargaTime;\n try {\n if (globals.getAntecedentesMuestreo().getTimeMuestreo() == null) {\n Toast.makeText(getContext(), \"No se ha definido hora de muestreo\", Toast.LENGTH_SHORT).show();\n horaDescarga.setText(\"\");\n } else {\n horaMuestreoTime = parser.parse(globals.getAntecedentesMuestreo().getTimeMuestreo());\n horaDescargaTime = parser.parse(time);\n if (horaMuestreoTime.before(horaDescargaTime)) {\n Toast.makeText(getContext(), \"Hora de descarga no puede ser mayor a la hora de muestreo\", Toast.LENGTH_SHORT).show();\n horaDescarga.setText(\"\");\n } else {\n\n if (globals.getAntecedentesMuestreo().getTimeCamion() == null) {\n Toast.makeText(getContext(), \"No se ha definido hora llegada camion\", Toast.LENGTH_SHORT).show();\n horaDescarga.setText(\"\");\n } else {\n horaCamionTime = parser.parse(globals.getAntecedentesMuestreo().getTimeCamion());\n\n horaDescargaTime = parser.parse(time);\n if (horaDescargaTime.after(horaCamionTime)) {\n\n horaDescarga.setText(time);\n globals.getAntecedentesMuestreo().setHoraDescarga(time);\n } else {\n Toast.makeText(getContext(), \"Hora de descarga no puede ser inferior a la hora de llegada camion\", Toast.LENGTH_SHORT).show();\n horaDescarga.setText(\"\");\n }\n }\n }\n }\n } catch (ParseException e) {\n horaDescarga.setText(\"\");\n }\n }\n }, hour, minute, true);\n mTimePicker.setTitle(\"Seleccione Hora\");\n mTimePicker.show();\n\n }", "@Override\n public void onClick(View v) {\n new DatePickerDialog(getActivity(), enddatepicker, trigger.getEndtime().get(Calendar.YEAR), trigger.getEndtime().get(Calendar.MONTH), trigger.getEndtime().get(Calendar.DAY_OF_MONTH)).show();\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog6 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t6Hour6 = hourOfDay1;\n t6Minute6 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t6Hour6, t6Minute6);\n //set selected time on text view\n\n\n timeE3 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editETime3.setText(timeE3);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog6.updateTime(t6Hour6, t6Minute6);\n //show dialog\n timePickerDialog6.show();\n }", "public void showStartTimeDialog(View v){\n DialogFragment dialogFragment = null;\n switch (v.getId()) {\n case R.id.newEvent_button_from_hour:\n dialogFragment = new StartTimePicker(0);\n break;\n case R.id.newEvent_button_to_hour:\n dialogFragment = new StartTimePicker(1);\n break;\n }\n dialogFragment.show(getFragmentManager(), \"start_time_picker\");\n }", "@Override\n public void onClick(View v) {\n\n TimePickerDialog timePickerDialog7 = new TimePickerDialog(add_sched.this, new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay1, int minute1) {\n //initialize hour and minute\n\n t7Hour7 = hourOfDay1;\n t7Minute7 = minute1;\n\n Calendar calendar = Calendar.getInstance();\n\n //set hour and minute\n calendar.set(0, 0, 0, t7Hour7, t7Minute7);\n //set selected time on text view\n\n\n timeS4 = String.valueOf((DateFormat.format(\"hh:mm aa\", calendar)));\n editSTime4.setText(timeS4);\n }\n }, 12, 0, false\n );\n // displayed previous selected time\n\n timePickerDialog7.updateTime(t7Hour7, t7Minute7);\n //show dialog\n timePickerDialog7.show();\n }", "@Override\n public void onClick(View v) {\n int hour = calendar.get(Calendar.HOUR_OF_DAY);\n int minute = calendar.get(Calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(getContext(), new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker, int selectedHour, int selectedMinute) {\n String time = (selectedHour > 9 ? selectedHour : \"0\" + selectedHour)\n + \":\" +\n (selectedMinute > 9 ? selectedMinute : \"0\" + selectedMinute);\n //validar hora\n plantaOut.setText(time);\n globals.getAntecedentesHormigonMuestreo().setPlantaOut(time);\n }\n }, hour, minute, true);\n mTimePicker.setTitle(\"Seleccione Hora\");\n mTimePicker.show();\n\n }", "public void viewAlarm() {\n\t\tfinal Dialog dialog = new Dialog(this);\n\t\tdialog.setContentView(R.layout.date_time_picker);\n\t\tdialog.setTitle(\"Set Reminder\");\n\t\tButton saveDate = (Button)dialog.findViewById(R.id.btnSave);\n\t\tsaveDate.setOnClickListener(new OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(View v) {\n\t\t\t\tdialog.dismiss();\n\t\t\t\tsetAlarm(dialog);\n\t\t\t}\n\t\t});\n\t\tdialog.show();\n\t}", "private void showTimePicker(){\n final Calendar c = Calendar.getInstance();\n mHour = c.get(Calendar.HOUR_OF_DAY);\n mMinute = c.get(Calendar.MINUTE);\n\n // Launch Time Picker Dialog\n TimePickerDialog tpd = new TimePickerDialog(this,\n new TimePickerDialog.OnTimeSetListener() {\n\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay,\n int minute) {\n // Display Selected time in textbox\n pickupTime.setText(hourOfDay + \":\" + minute);\n// Log.e(TAG,\"Time set: \" + mHour + \",\" + mMinute + \",\");\n }\n }, mHour, mMinute, false);\n\n tpd.show();\n }", "@Override\n public void onClick(View v) {\n\n Calendar mcurrentTime = Calendar.getInstance();\n int hour = mcurrentTime.get(Calendar.HOUR_OF_DAY);\n int minute = mcurrentTime.get(Calendar.MINUTE);\n TimePickerDialog mTimePicker;\n mTimePicker = new TimePickerDialog(\n Attend_Regularization.this,\n new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker timePicker,\n int selectedHour, int selectedMinute) {\n\n String am_pm = \"\";\n\n Calendar datetime = Calendar.getInstance();\n datetime.set(Calendar.HOUR_OF_DAY, selectedHour);\n datetime.set(Calendar.MINUTE, selectedMinute);\n\n if (datetime.get(Calendar.AM_PM) == Calendar.AM)\n am_pm = \"AM\";\n else if (datetime.get(Calendar.AM_PM) == Calendar.PM)\n am_pm = \"PM\";\n\n String strHrsToShow = (datetime\n .get(Calendar.HOUR) == 0) ? \"12\"\n : datetime.get(Calendar.HOUR) + \"\";\n\n in_time.setText(strHrsToShow + \":\"\n + pad(datetime.get(Calendar.MINUTE))\n + \" \" + am_pm);\n\n /*if (out_time.getText().toString().trim().equals(\"\")) {\n\n } else {\n if (!in_date.getText().toString().trim().isEmpty() && !out_date.getText().toString().trim().isEmpty()) {\n if (in_date.getText().toString().trim().equals(out_date.getText().toString().trim())) {\n String resultcampare = CompareTime(in_time.getText().toString().trim(), out_time.getText().toString().trim());\n if (!resultcampare.equals(\"1\")) {\n\n EmpowerApplication.alertdialog(for_out_time, Attend_Regularization.this);\n\n }\n }\n } else {\n if (!validateindate())\n return;\n if (!validateoutdate())\n return;\n }\n }*/\n // edtxt_time.setTextColor(Color.parseColor(\"#000000\"));\n\n }\n }, hour, minute, false);// Yes 24 hour time\n mTimePicker.setTitle(\"Select Time\");\n mTimePicker.show();\n getWindow().setSoftInputMode(WindowManager.LayoutParams.SOFT_INPUT_STATE_HIDDEN);\n\n }", "private void pickTime(final Calendar initTime){\n //callback once time is selected\n TimePickerDialog.OnTimeSetListener setTime = new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n initTime.set(\n initTime.get(Calendar.YEAR),\n initTime.get(Calendar.MONTH),\n initTime.get(Calendar.DATE),\n hourOfDay,\n minute\n );\n setDateTimeViews(); //updates views\n }\n };\n //creates dialogue\n TimePickerDialog timePickerDialog = new TimePickerDialog(this,\n setTime,\n initTime.get(Calendar.HOUR_OF_DAY),\n initTime.get(Calendar.MINUTE),\n false);\n timePickerDialog.show(); //shows the dialogue\n }", "@NonNull\n @Override\n public Dialog onCreateDialog(@Nullable Bundle savedInstanceState) {\n final Calendar calendar = Calendar.getInstance();\n int hour = calendar.get(Calendar.HOUR_OF_DAY);\n int minute = calendar.get(Calendar.MINUTE);\n\n // recover from where we came\n Bundle bundle = this.getArguments();\n if(bundle != null)\n from = bundle.getString(\"from\", \"null\");\n\n // Create a new instance of TimePickerDialog and return it\n return new TimePickerDialog(getActivity(), new TimePickerDialog.OnTimeSetListener() {\n @Override\n public void onTimeSet(TimePicker view, int hourOfDay, int minute) {\n calendar.set(Calendar.HOUR_OF_DAY, hourOfDay);\n calendar.set(Calendar.MINUTE, minute);\n String am_pm = calendar.get(Calendar.AM_PM) == Calendar.AM ? \"am\" : \"pm\";\n\n if(hourOfDay > 12)\n hourOfDay -= 12;\n\n if(hourOfDay == 0 && am_pm.equals(\"am\"))\n hourOfDay = 0;\n\n if(hourOfDay == 0 && am_pm.equals(\"pm\"))\n hourOfDay = 12;\n\n if(!from.equals(\"null\")){\n TextView time;\n SharedPreferences sp = getActivity().getSharedPreferences(\"prefTime\", getActivity().MODE_PRIVATE);\n SharedPreferences.Editor editor = sp.edit();\n\n // update textview and shared preferences\n if(from.equals(\"fromTime\")) {\n time = (TextView)getActivity().findViewById(R.id.fromTime_ID);\n editor.putInt(\"fromHour\", hourOfDay);\n editor.putInt(\"fromMinute\", minute);\n editor.putString(\"am_pm_from\", am_pm);\n }\n else {\n time = (TextView)getActivity().findViewById(R.id.toTime_ID);\n editor.putInt(\"toHour\", hourOfDay);\n editor.putInt(\"toMinute\", minute);\n editor.putString(\"am_pm_to\", am_pm);\n }\n time.setText(String.format(\"%02d\", hourOfDay) + \":\" + String.format(\"%02d\", minute) + \" \" + am_pm);\n\n editor.commit();\n }\n }\n }, hour, minute, false);\n }" ]
[ "0.7639344", "0.7096858", "0.70474505", "0.70363283", "0.69886345", "0.6961351", "0.6884426", "0.6868672", "0.68243927", "0.6794674", "0.6780464", "0.6751257", "0.6750552", "0.6741721", "0.67204475", "0.6717374", "0.6693069", "0.66762716", "0.66712755", "0.6670151", "0.66687435", "0.66642386", "0.6662746", "0.66592014", "0.6652326", "0.6652002", "0.6648892", "0.66423076", "0.6638742", "0.66383934", "0.66335696", "0.6633335", "0.6632038", "0.66310114", "0.6629828", "0.66292316", "0.66268", "0.66266954", "0.66257054", "0.6623341", "0.6621286", "0.6618701", "0.66175693", "0.6615046", "0.6611502", "0.6609551", "0.6607655", "0.66058296", "0.66029495", "0.6602725", "0.6593199", "0.65908617", "0.6590664", "0.65837204", "0.6583478", "0.6582126", "0.6578604", "0.657578", "0.65693456", "0.65573466", "0.65566", "0.6556039", "0.65492094", "0.6544003", "0.65344346", "0.6534114", "0.653182", "0.65315026", "0.652987", "0.6525649", "0.6520822", "0.6519025", "0.6518494", "0.65177625", "0.65160733", "0.65158427", "0.65014875", "0.6495871", "0.64943326", "0.6484586", "0.6480065", "0.64702684", "0.64649427", "0.6461945", "0.6452871", "0.6448153", "0.64451396", "0.6441314", "0.6440685", "0.64334524", "0.64226586", "0.64195365", "0.64184135", "0.64178646", "0.6392543", "0.63865393", "0.63778377", "0.6367768", "0.63347644", "0.63248765" ]
0.769149
0
Updates the text views.
private void updateTextViews(String timeStamp, boolean isGi, int amount, String stress, String tired, boolean isPhysicallyActive, boolean hasAlcoholConsumed, boolean isIll, boolean takesMedication, boolean hasPeriod, int mv0, int mv15, int mv30, int mv45, int mv60, int mv75, int mv90, int mv105, int mv120) { /* Update text views */ // Time information mBinding.date.setText( Converter.convertTimeStampToDate(timeStamp)); mBinding.time .setText(Converter.convertTimeStampToTimeStart(timeStamp)); // Advance information mBinding.amount.setText(Converter.convertInteger(amount)); // If GI measurement disable amount text field if (isGi) { mBinding.amount.setEnabled(false); } mBinding.stress.setText(stress); mBinding.tired.setText(tired); mBinding.physicallyActive.setChecked(isPhysicallyActive); mBinding.alcoholConsumed.setChecked(hasAlcoholConsumed); // Events mBinding.ill.setChecked(isIll); mBinding.medication.setChecked(takesMedication); mBinding.period.setChecked(hasPeriod); // Glucose Values mBinding.mv0.setText(Converter.convertIntegerMeasurement(mv0)); mBinding.mv15.setText(Converter.convertIntegerMeasurement(mv15)); mBinding.mv30.setText(Converter.convertIntegerMeasurement(mv30)); mBinding.mv45.setText(Converter.convertIntegerMeasurement(mv45)); mBinding.mv60.setText(Converter.convertIntegerMeasurement(mv60)); mBinding.mv75.setText(Converter.convertIntegerMeasurement(mv75)); mBinding.mv90.setText(Converter.convertIntegerMeasurement(mv90)); mBinding.mv105.setText(Converter.convertIntegerMeasurement(mv105)); mBinding.mv120.setText(Converter.convertIntegerMeasurement(mv120)); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void updateTextViews() {\n // Set the inputs according to the initial input from the entry.\n //TextView dateTextView = (TextView) findViewById(R.id.date_textview);\n //dateTextView.setText(DateUtils.formatDateTime(getApplicationContext(), mEntry.getStart(), DateUtils.FORMAT_SHOW_DATE));\n\n EditText dateEdit = (EditText) findViewById(R.id.date_text_edit);\n dateEdit.setText(DateUtils.formatDateTime(this, mEntry.getStart(), DateUtils.FORMAT_NUMERIC_DATE | DateUtils.FORMAT_SHOW_DATE | DateUtils.FORMAT_SHOW_YEAR | DateUtils.FORMAT_ABBREV_ALL));\n\n EditText startTimeEdit = (EditText) findViewById(R.id.start_time_text_edit);\n startTimeEdit.setText(DateUtils.formatDateTime(this, mEntry.getStart(), DateUtils.FORMAT_SHOW_TIME));\n\n EditText endTimeEdit = (EditText) findViewById(R.id.end_time_text_edit);\n endTimeEdit.setText(DateUtils.formatDateTime(this, mEntry.getEnd(), DateUtils.FORMAT_SHOW_TIME));\n\n\n TextView descriptionView = (TextView) findViewById(R.id.description);\n descriptionView.setText(mEntry.getDescription());\n\n\n enableSendButtonIfPossible();\n }", "private void update(String text, TextView view) {\r\n handler.post(new TextUpdater(text, view));\r\n }", "private void updateViews() {\n titleTextView.setText(currentVolume.getTitle());\n descTextView.setText(Html.fromHtml(currentVolume.getDesc(), Html.FROM_HTML_MODE_COMPACT));\n authorsTextView.setText(currentVolume.getAuthors());\n\n retrieveImage();\n }", "public void updateViews() {\n this.titleTextView.setText(title);\n this.authorTextView.setText(author);\n this.yearTextView.setText(String.valueOf(year));\n this.publisherTextView.setText(publisher);\n if (endsDate != \"\") {\n this.lentToDateTextView.setText(endsDate);\n } else {\n this.lentToDateTextView.setVisibility(View.GONE);\n this.lentToDateLabelTextView.setVisibility(View.GONE);\n }\n }", "private void updateText() {\n updateDateText();\n\n TextView weightText = findViewById(R.id.tvWeight);\n TextView lowerBPText = findViewById(R.id.tvLowerBP);\n TextView upperBPText = findViewById(R.id.tvUpperBP);\n\n mUser.weight.sortListByDate();\n mUser.bloodPressure.sortListsByDate();\n\n double weight = mUser.weight.getWeightByDate(mDate.getTime());\n int upperBP = mUser.bloodPressure.getUpperBPByDate(mDate.getTime());\n int lowerBP = mUser.bloodPressure.getLowerBPByDate(mDate.getTime());\n\n weightText.setText(String.format(Locale.getDefault(), \"Paino\\n%.1f\", weight));\n lowerBPText.setText(String.format(Locale.getDefault(), \"AlaP\\n%d\", lowerBP));\n upperBPText.setText(String.format(Locale.getDefault(), \"YläP\\n%d\", upperBP));\n\n ((EditText)findViewById(R.id.etWeight)).setText(\"\");\n ((EditText)findViewById(R.id.etLowerBP)).setText(\"\");\n ((EditText)findViewById(R.id.etUpperBP)).setText(\"\");\n }", "public void updateTextView(final String text)\n\t{\n\t\tmHandler.post(new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\tt.setText(text);\n\t\t\t}\n\t\t});\n\t}", "public void updateViews() {\n textView.setText(contactName);\n\n }", "void updateView();", "void updateView();", "public void updateViews() {\n updateViews(null);\n }", "public void update() {\n\t\tthis.editorView.update();\n\t}", "protected void updateTextChange() {\n \t\t\tfText= fDocumentUndoManager.fTextBuffer.toString();\n \t\t\tfDocumentUndoManager.fTextBuffer.setLength(0);\n \t\t\tfPreservedText= fDocumentUndoManager.fPreservedTextBuffer.toString();\n \t\t\tfDocumentUndoManager.fPreservedTextBuffer.setLength(0);\n \t\t}", "private void refreshText() {\n mTagsCountText.setText(String.valueOf(tagList.size()));\n\n }", "private void updateText(int nr, View v) {\n if (v.equals(teamAScoreButton)) {\n teamAScoreTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamBScoreButton)) {\n teamBScoreTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamAFaultButton)) {\n teamAFaultTextView.setText(String.valueOf(nr));\n } else if (v.equals(teamBFaultButton)) {\n teamBFaultTextView.setText(String.valueOf(nr));\n }\n }", "private void updateViews() {\n String twtText = tweetInput.getText().toString();\n int elapsedLength = MAX_CHAR_COUNT - twtText.length();\n if (elapsedLength >= 0 && elapsedLength < MAX_CHAR_COUNT) {\n btnTweet.setEnabled(true);\n charCounter.setTextColor(getResources().getColor(COLOR_GRAY));\n } else {\n btnTweet.setEnabled(false);\n charCounter.setTextColor(getResources().getColor(COLOR_RED));\n }\n\n charCounter.setText(\"\" + elapsedLength);\n }", "void updateText(int c) {\n postInvalidate();\n }", "public void updateText(String s){\n TextView articleText = (TextView) findViewById(R.id.article_text);\n articleText.setText(s);\n }", "private void updateViews(TextView scoreView, TextView timesPlayedView,\n Button numButton1, Button numButton2) {\n //create the text that will be shown. In this case, the text will look like \"Score: 2\".\n String userScoreString = String.format(\"%s %d\",\n getString(R.string.score_text), model.getUserScore());\n\n String userTimesPlayedString = String.format(\"%s %d\",\n getString(R.string.times_played_text), model.getUserTimesPlayed());\n\n //update the textViews\n scoreView.setText(userScoreString);\n timesPlayedView.setText(userTimesPlayedString);\n\n //update the buttons\n numButton1.setText(String.format(\"%d\", model.getLeftnumber()));\n numButton2.setText(String.format(\"%d\", model.getRightNumber()));\n }", "public void setTxtViews(){\n \tupdateTextView(\"Phil Simms\", \"txtPatientName\");\n \tupdateTextView(\"Male\", \"txtPatientGender\");\n \tupdateTextView(\"24\", \"txtPatientAge\");\n \tupdateTextView(\"13\", \"txtPatientRoom\");\n \tupdateTextView(\"Melanoma\", \"txtPatientDiagnosis\");\n \tupdateTextView(\"165\", \"txtPatientWeight\");\n \tupdateTextView(\"10am: Gave tylenol for headache.\", \"txtPatientRecentActions\");\n \tupdateTextView(\"Beach\", \"txtPatientNotes\");\n }", "private void updateView() {\n model.inlezenHighscore();\n for (int i = 0; i < 10; i++) {\n view.getNaamLabels(i).setText(model.getNaam(i));\n view.getScoreLabels(i).setText(model.getScores(i));\n }\n }", "private void updateViews() {\n\t\tList<Task> list = null;\n\t\tDBHelper db = new DBHelper();\n\t\ttry {\n\t\t\tlist = db.getTaskList(this, Task.COLUMN_ID, taskID);\n\n\t\t} catch (SQLException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\tLog.e(\"Could not get Single Task\", \"Bam\", e);\n\t\t}\n\n\t\ttask = list.get(0);\n\n\t\tint prioPos = 0;\n\n\t\tfor (int i = 0; i < prioList.size(); i++) {\n\n\t\t\tif (prioList.get(i).getId() == task.getPriority().getId()) {\n\t\t\t\tprioPos = i;\n\t\t\t\tbreak;\n\t\t\t}\n\n\t\t}\n\t\tprioSpinner.setSelection(prioPos);\n\n\t\tint catPos = 0;\n\n\t\tfor (int i = 0; i < categoryList.size(); i++) {\n\n\t\t\tif (categoryList.get(i).getId() == task.getCategory().getId()) {\n\t\t\t\tcatPos = i;\n\t\t\t\tbreak;\n\t\t\t}\n\n\t\t}\n\t\tcategorySpinner.setSelection(catPos);\n\n\t\ttitle.setText(task.getTitle());\n\t\tdescription.setText(task.getDescription());\n\t\tdatePicker.updateDate(task.getAblaufJahr(), task.getAblaufMonat(),\n\t\t\t\ttask.getAblaufTag());\n\t}", "@Override\r\n\tpublic void updateView(int parseInt, int parseInt2, String string) {\n\r\n\t}", "private void updateCounterView(String text) {\n final String txt = text;\n main.runOnUiThread(new Runnable() {\n @Override\n public void run() {\n if(txt!=null) {\n pointsLeftView.setText(txt);\n } else {\n pointsLeftView.setText(Integer.toString(counter));\n }\n }\n });\n }", "private void viewChange() {\n currentView = (TextView) findViewById(R.id.currView);\n currentView.setText(counters.get(counterPosition).toString());\n }", "public void updateTaskViews(){\n for (Task task : taskManager.getTasksList()){\n TextView textToChange = (TextView) root.findViewById(task.getIdInView());\n if (textToChange == null){\n submit(task.getName(), task.getIdInView(), task.getTimeForTask(), task.isFinished());\n } else {\n textToChange.setText(task.getName());\n }\n }\n }", "public void updateText( String text ) {\n\t\tthis.text = text;\n\t}", "private void updateText(){\n\t\tif(propertiesObj == null)\n\t\t\treturn;\n\n\t\tif(propertiesObj instanceof QuestionDef)\n\t\t\t((QuestionDef)propertiesObj).setText(txtText.getText());\n\t\telse if(propertiesObj instanceof OptionDef)\n\t\t\t((OptionDef)propertiesObj).setText(txtText.getText());\n\t\telse if(propertiesObj instanceof PageDef)\n\t\t\t((PageDef)propertiesObj).setName(txtText.getText());\n\t\telse if(propertiesObj instanceof FormDef)\n\t\t\t((FormDef)propertiesObj).setName(txtText.getText());\n\n\t\tformChangeListener.onFormItemChanged(propertiesObj);\n\t}", "private void updateInformation(){\n view.getPrompt().setText(getPrompt());\n view.getScore().setText(getScore());\n }", "private void updateView() {\r\n if (this.nodes == null || this.nodes.length > 1\r\n || !this.nodes[0].exists()) {\r\n this.titleBorder.setTitle(\"-\");\r\n this.jzvStat.setStat(null);\r\n this.taUpdate.setText(\"\");\r\n this.taChildData.setText(\"\");\r\n this.jbUpdate.setEnabled(false);\r\n this.jbNewChild.setEnabled(false);\r\n this.jbDelete.setEnabled(this.nodes != null);\r\n } else {\r\n this.titleBorder.setTitle(this.nodes[0].getPath());\r\n this.jzvStat.setStat(this.nodes[0].getStat());\r\n byte[] data = this.nodes[0].getData();\r\n this.taUpdate.setText(new String(data == null ? \"null\".getBytes()\r\n : data));\r\n this.taChildData.setText(\"\");\r\n this.jbUpdate.setEnabled( !this.taUpdate.getText().trim().equals(\"\") );\r\n this.jbNewChild.setEnabled( !this.jtfChildName.getText().trim().equals(\"\") );\r\n this.jbDelete.setEnabled(true);\r\n }\r\n this.repaint();\r\n }", "public void update() {\r\n if (parseStyle == ParseStyle.CHARACTER) {\r\n wrapText();\r\n int begin = getPosition();\r\n int end = getPosition() + 1;\r\n setCurrentItem(new TextItem(begin, end, getText().substring(begin,\r\n end)));\r\n setPosition(end);\r\n } else if (parseStyle == ParseStyle.WORD) {\r\n if (matcher == null) {\r\n return;\r\n }\r\n wrapText();\r\n boolean matchFound = findNextToken();\r\n if (matchFound) {\r\n selectCurrentToken();\r\n } else {\r\n // No match found. Go back to the beginning of the text area\r\n // and select the first token found\r\n setPosition(0);\r\n updateMatcher();\r\n // Having wrapped to the beginning select the next token, if\r\n // there is one.\r\n if (findNextToken()) {\r\n selectCurrentToken();\r\n }\r\n }\r\n }\r\n\r\n }", "public void fillText(View view){\n if(running==true){\n\n\n latestOp=false;\n for(int i = 0; i<9; i++)\n if(i==win&&idOfViews[i]==view.getId()) {\n score++;\n sec=sec+3;\n latestOp=true;\n }\n\n //Defining the score\n total++;\n scoret.setText(\" \"+score+\" /\"+total);\n\n //Setting the message about the latest one.\n resultT.setText(\"Missed\");\n if(latestOp==true)\n resultT.setText(\"Correct!\");\n\n\n //Calling a new screen\n newScreen();\n }\n\n\n }", "private void updateDisplay() \n\t{\n\t\t// updates the date in the TextView\n if(bir.hasFocus())\n {\n\t\tbir.setText(\n\t\t\t\tnew StringBuilder()\n\t\t\t\t// Month is 0 based so add 1\n\t\t\t\t\n\t\t\t\t.append(mDay).append(\"-\")\n\t\t\t\t.append(mMonth + 1).append(\"-\")\n\t\t\t\t.append(mYear).append(\" \"));\n }else\n {\n\t\taniv.setText(\n\t\t\t\tnew StringBuilder()\n\t\t\t\t// Month is 0 based so add 1\n\t\t\t\t\n\t\t\t\t.append(mDay).append(\"-\")\n\t\t\t\t.append(mMonth + 1).append(\"-\")\n\t\t\t\t.append(mYear).append(\" \"));\n }\n\n\n\t}", "public void updateAllViews()\r\n { for (IView view : this.views)\r\n { view.updateView();\r\n }\r\n }", "public void updateView(String message) {\n output.setText(message);\n \n }", "@Override\n\t\t\t\t\t\t\tpublic void run() {\n\t\t\t\t\t\t\t\ttextView.setText(text);\n\t\t\t\t\t\t\t}", "private void swapContent(){\n Editable content = WordText.getText();\n WordText.setText(TranText.getText());\n TranText.setText(content);\n\n }", "private void updateView()\r\n\t{\r\n\t\tsupportDatabase.openDataBase();\r\n\t\t\r\n\t\tString language = supportDatabase.getUserSelectedLanguage();\r\n\t\t\r\n\t\tCursor about_info = supportDatabase.getInfoInLanguage(\"Activity_About\", language);\r\n\t\tstartManagingCursor(about_info);\r\n\t\t\r\n\t\tif(about_info.getCount()==1)\r\n\t\t{\r\n\t\t\tabout_info.moveToFirst();\r\n\t\t\taboutHeaderTextView.setText(about_info.getString(about_info.getColumnIndex(\"aboutHeader\")));\r\n\t\t versionTextView.setText(about_info.getString(about_info.getColumnIndex(\"version\")));\r\n\t copyrightTextView.setText(about_info.getString(about_info.getColumnIndex(\"copyright\")));\r\n\t creditsTextView.setText(about_info.getString(about_info.getColumnIndex(\"credits\")));\r\n\t\t\t\r\n\t\t}\r\n//TODO\t\t\t\r\n\t\t\tsupportDatabase.close();\r\n\t\t\r\n\t}", "private void setTextViews() {\n TextView textToggleFilters = (TextView) findViewById(R.id.text_totalExpenditure);\n textToggleFilters.setPaintFlags(textToggleFilters.getPaintFlags() | Paint.FAKE_BOLD_TEXT_FLAG);\n }", "private void setText(View view, String text) {\n\t\t((TextView) view.findViewById(android.R.id.text1)).setText(text);\n\t}", "protected TextView setText( final int childViewIndex, final CharSequence text )\n {\n return updater.setText( childViewIndex, text );\n }", "private void setupTextView() {\n painterTextViewMoves = findViewById(R.id.painterTextView1);\n painterTextViewTime = findViewById(R.id.painterTextView2);\n painterTextViewPoints = findViewById(R.id.painterTextView3);\n painterTextViewInstructions = findViewById(R.id.painterInstructionsView);\n }", "private void updateTransferText() {\n downloadsLine.setValue((Integer) downloadsCountVM.getValue());\n uploadsLine.setValue((Integer) uploadsCountVM.getValue());\n }", "public void updateText() throws JUIGLELangException {\n SwingUtilities.invokeLater(new Runnable() {\n\n\n public void run() {\n fireTableStructureChanged();\n }\n });\n\n }", "public void updateViews() {\n\t\tif (App.isInitialized() && App.getPlayer().isPlaying()) {\r\n\t\t\tactionButton.setImageResource(R.drawable.ic_media_pause);\r\n\t\t} else {\r\n\t\t\tactionButton.setImageResource(R.drawable.ic_media_play);\r\n\t\t}\r\n\t\t\r\n\t\t// Update the seek text\r\n\t\tint seek = App.getPlayer().getSeek();\r\n\t\tint duration = App.getPlayer().getDuration();\r\n\t\tseekText.setText(Utilities.formatTime(seek));\r\n\t\tdurationText.setText(Utilities.formatTime(duration));\r\n\t\t\r\n\t\t// Update the seek progress\r\n\t\tseekBar.setMax(duration);\r\n\t\tif (autoUpdateSeek) {\r\n\t\t\tseekBar.setProgress(seek);\r\n\t\t}\r\n\t}", "private void updateCountTV()\n {\n TextView countTextview = (TextView) findViewById(R.id.countTV);\n countTextview.setText(\"Counting Jelly Beans gives me \" + countJB);\n }", "protected void updateVolumeTextView(String text) {\n mVolTextView.setText(text);\n }", "public void updateView()\n {\n int selectionCount = selection.getElementSelectionCount();\n\n // If only one item selected, enable & update the\n // text boxes and pull downs with values.\n if (selectionCount == 1) {\n // preserve selected state if a whole text field is selected\n Text text = WindowUtil.getFocusedText();\n boolean restoreSel = false;\n if ((text != null) &&\n (text.getSelectionCount() == text.getCharCount()))\n {\n restoreSel = true;\n }\n\n // get the selected item\n Iterator<FrameElement> iter =\n selection.getSelectedElementsIterator();\n\n // For each selected object, which there is only one.\n FrameElement elt = iter.next();\n\n if (elt instanceof IWidget) {\n IWidget widget = (IWidget) elt;\n\n view.useParameters(FrameEditorView.USE_SINGLE_SELECT);\n view.updateWidgetProperties(widget);\n }\n else if (elt instanceof FrameElementGroup) {\n FrameElementGroup eltGroup = (FrameElementGroup) elt;\n\n view.useParameters(FrameEditorView.USE_GROUP_SELECT);\n view.updateEltGroupProperties(eltGroup);\n }\n\n // Restore the selection state\n if (restoreSel) {\n text.selectAll();\n }\n }\n else if (selectionCount > 1) {\n // TODO: on multi selection, some values are left enabled\n // We need to set these to something or disable them.\n view.useParameters(FrameEditorView.USE_MULTI_SELECT);\n }\n else {\n view.useParameters(FrameEditorView.USE_NONE);\n view.updateFrameProperties(frame, false);\n }\n }", "private void update_text() {\n\n if(i < text_data.length) {\n i++;\n // text_data.setText(String.valueOf(i)); = avoid the RunTime error\n myHandler.post(myRunnable); // relate this to a Runnable\n } else {\n myTimer.cancel(); // stop the timer\n return;\n }\n }", "private void flushImpl() {\r\n String s = null;\r\n\r\n // grab data from the buffer\r\n synchronized (this) {\r\n if (buffer.length() > 0) {\r\n s = buffer.toString();\r\n buffer.setLength(0);\r\n }\r\n }\r\n\r\n // don't do anything if buffer was empty\r\n if (s != null) {\r\n try {\r\n boolean scroll = false;\r\n Document d = textViewer.getDocument();\r\n int docLen = d.getLength();\r\n if (docLen > 0) {\r\n scroll = (textViewer.getCaretPosition() >= (docLen-1));\r\n }\r\n\r\n // Insert new text:\r\n d.insertString(d.getLength(), s, attributes);\r\n\r\n // Is number of lines limited?\r\n if (isSizeLimited() && docLen > getMaxSize()) {\r\n Element root = d.getDefaultRootElement();\r\n int i = root.getElementIndex(docLen - getMaxSize());\r\n if (i >= 0) {\r\n Element e = root.getElement(i);\r\n int offset = e.getEndOffset();\r\n d.remove(0,Math.min(offset,docLen));\r\n }\r\n }\r\n\r\n // Scroll view to the end only if cursor was at the end:\r\n if (scroll) {\r\n textViewer.setCaretPosition(d.getLength());\r\n }\r\n\r\n // Update summary view:\r\n if (summaryView != null && d.getLength() > 0) {\r\n Element root = d.getDefaultRootElement();\r\n int n = root.getElementCount();\r\n if (n > 0) {\r\n Element last = root.getElement(n-1);\r\n int start = last.getStartOffset();\r\n int end = last.getEndOffset();\r\n if ((end-start) <= 1 && n > 1) {\r\n last = root.getElement(n-2);\r\n start = last.getStartOffset();\r\n end = last.getEndOffset();\r\n }\r\n\r\n AttributeSet a = last.getAttributes();\r\n Object fg = a.getAttribute(StyleConstants.Foreground);\r\n Object bg = a.getAttribute(StyleConstants.Background);\r\n if (!(fg instanceof Color)) {\r\n fg = LookFactory.getCodeColorSet().foregroundColor;\r\n }\r\n if (!(bg instanceof Color)) {\r\n bg = LookFactory.getCodeColorSet().backgroundColor;\r\n }\r\n summaryView.setForeground((Color)fg);\r\n summaryView.setBackground((Color)bg);\r\n\r\n String text = d.getText(start,end-start);\r\n if (text.length() > 0) {\r\n summaryView.setText(text);\r\n } else {\r\n summaryView.clear();\r\n }\r\n }\r\n }\r\n\r\n // Write the file:\r\n if (fileWriter != null) {\r\n char lastChar = lastFileChar;\r\n int len = s.length();\r\n for (int i=0; i<len; i++) {\r\n char c = s.charAt(i);\r\n if (c == '\\n') {\r\n if (lastFileChar == '\\r') {\r\n fileWriter.write(c);\r\n } else {\r\n // Use platform-specific end of line seq\r\n fileWriter.println();\r\n }\r\n } else {\r\n fileWriter.write(c);\r\n }\r\n lastChar = c;\r\n }\r\n\r\n lastFileChar = lastChar;\r\n fileWriter.flush();\r\n }\r\n\r\n } catch(Exception ex) {\r\n ex.printStackTrace();\r\n }\r\n }\r\n }", "public void updateUi() {\n updateTextView(R.id.blindword, gameInstance.getBlindWord(), EditMode.ADDSPACING);\n updateTextView(R.id.guessedletters, gameInstance.getGuessedSoFar(), EditMode.ADDSPACING);\n\n int livesTotal = settings.getInt(\"lives\", 7);\n int livesLeft = gameInstance.getLives();\n StringBuilder healthbar = new StringBuilder();\n for(int i=0;i<livesLeft;i++) {\n healthbar.append('\\u2764'); //black heart\n }\n\n for(int i=0;i<(livesTotal - livesLeft);i++) {\n healthbar.append('\\u2661'); //white heart\n }\n\n updateTextView(R.id.healthbar, healthbar.toString(), EditMode.NONE);\n\n gameOverListener();\n\n }", "private void setViews() {\n\n TextView currentApixu = findViewById(R.id.currentApixu);\n TextView currentOwm = findViewById(R.id.currentOwm);\n TextView currentWu = findViewById(R.id.currentWu);\n\n currentApixu.setText(feedValues[0]);\n currentOwm.setText(feedValues[1]);\n currentWu.setText(feedValues[2]);\n }", "private void initViews() {\n charCounter = (TextView) findViewById(R.id.tv_char_counter);\n tweetInput = (EditText) findViewById(R.id.et_tweet_input);\n btnTweet = (Button) findViewById(R.id.btn_tweet);\n\n tweetInput.addTextChangedListener(new TextWatcher() {\n @Override\n public void beforeTextChanged(CharSequence charSequence, int i, int i2, int i3) {\n }\n\n @Override\n public void onTextChanged(CharSequence charSequence, int i, int i2, int i3) {\n }\n\n @Override\n public void afterTextChanged(Editable editable) {\n updateViews();\n }\n });\n }", "private void updateOutputText() {\r\n UiApplication.getUiApplication().invokeLater(new Runnable() {\r\n public void run() {\r\n _outputText.setText(_output);\r\n }\r\n });\r\n }", "@Override\n public void update() {\n CommandNodeGameState gs = (CommandNodeGameState) state;\n String acc = String.valueOf(gs.getAcc());\n accView.setText(acc);\n String bak = String.valueOf(gs.getBak());\n bakView.setText(bak);\n String last = String.valueOf(gs.getLast());\n lastView.setText(last);\n String mode = String.valueOf(gs.getMode());\n modeView.setText(mode);\n String idle = String.valueOf(0);\n idleView.setText(idle);\n\n StringBuilder builder = new StringBuilder();\n for (int i = 0; i < gs.lineCount(); i++) {\n builder.append(gs.getLine(i).toString());\n builder.append(\"\\n\");\n }\n textArea.setText(builder.toString());\n\n if (state.isActive()) {\n highlightedLine = gs.getSelectedLine();\n } else {\n highlightedLine = null;\n }\n invalidate();\n }", "private void updateViews() {\n if (mStructure == null || mThermostat == null) {\n return;\n }\n\n display_temp = mThermostat.getTargetTemperatureC();\n Log.v(TAG,\"updateViews: display_temp=\"+display_temp);\n // updates all views\n updateAmbientTempTextView();\n updateMenuItems();\n updateThermostatViews();\n updateControlView();\n\n //update the seekbar progress\n double temp = display_temp;\n mTempSeekbar.setProgress(0);\n display_temp = temp;\n mTempSeekbar.setProgress((int)((display_temp-9)/(32-9)*100));\n }", "private void setStatTextViews() {\n TextView numLives = findViewById(R.id.lives);\n numLives.setText(String.valueOf(player.getLives()));\n\n TextView multiplier = findViewById(R.id.currMultiply);\n multiplier.setText(String.valueOf(player.getMultiplier()));\n\n TextView totalPoint = findViewById(R.id.currScore);\n totalPoint.setText(String.valueOf(player.getPoints()));\n }", "private void populateTextViews() {\n full_name_tv.setText(contact.getFullName());\n school_tv.setText(contact.getSchool());\n department_tv.setText(getDepartmentString());\n email.setText(contact.getEmail());\n number_tv.setText(contact.getNumber());\n }", "protected TextView textView( final int childViewIndex )\n {\n return updater.textView( childViewIndex );\n }", "private void setTextWithContent(int index, JSONObject jsonObject) {\n try {\n TextView textView = (TextView) viewAll\n .findViewById(dayTextView[index]);\n String day = jsonObject.getString(\"date\");\n String week = Util.getWeekByDayString(day);\n String txt_d = jsonObject.getString(\"txt_d\");\n String txt_n = jsonObject.getString(\"txt_n\");\n String afasf = txt_d;\n SpannableString spannableString = new SpannableString(week + \"\\n\"\n + afasf);\n spannableString.setSpan(new AbsoluteSizeSpan(12, true),\n week.length(), week.length() + afasf.length() + 1,\n SpannableString.SPAN_EXCLUSIVE_EXCLUSIVE);\n textView.setText(spannableString);\n\n TextView textViewS = (TextView) viewAll\n .findViewById(dayTextViewN[index]);\n SpannableString spannableString2 = new SpannableString(txt_n);\n spannableString2.setSpan(new AbsoluteSizeSpan(12, true), 0,\n txt_n.length(), SpannableString.SPAN_EXCLUSIVE_EXCLUSIVE);\n textViewS.setText(spannableString2);\n\n ImageView IMAGEAe = (ImageView) viewAll\n .findViewById(iconView[index]);\n Util.setQingYinImage(IMAGEAe, afasf, true);\n\n ImageView IMAGEAdddde = (ImageView) viewAll\n .findViewById(iconViewN[index]);\n Util.setQingYinImage(IMAGEAdddde, txt_n, false);\n\n TextView tempTextVieadAsdw = (TextView) viewAll\n .findViewById(tempTextView[index]);\n String adasf = jsonObject.getString(\"min_tmp\") + \"/\"\n + jsonObject.getString(\"max_tmp\");\n Util.setTempreTure(adasf, tempTextVieadAsdw);\n\n } catch (Exception e) {\n // TODO Auto-generated catch block\n e.printStackTrace();\n }\n }", "private void setUpTextViews() {\n // Find views\n TextView userName0 = (TextView) findViewById(R.id.user_name_0);\n TextView userInfo0 = (TextView) findViewById(R.id.user_info_0);\n TextView userName1 = (TextView) findViewById(R.id.user_name_1);\n TextView userInfo1 = (TextView) findViewById(R.id.user_info_1);\n TextView userName2 = (TextView) findViewById(R.id.user_name_2);\n TextView userInfo2 = (TextView) findViewById(R.id.user_info_2);\n\n // Set text\n userName0.setText(mGroupMembers.get(0).getString(ParseConstants.KEY_FIRST_NAME));\n userInfo0.setText(mGroupMembers.get(0).getString(ParseConstants.KEY_AGE) +\n \" : : \" +\n (mGroupMembers.get(0).getString(ParseConstants.KEY_HOMETOWN)));\n\n userName1.setText(mGroupMembers.get(1).getString(ParseConstants.KEY_FIRST_NAME));\n userInfo1.setText(mGroupMembers.get(1).getString(ParseConstants.KEY_AGE) +\n \" : : \" +\n (mGroupMembers.get(1).getString(ParseConstants.KEY_HOMETOWN)));\n\n userName2.setText(mGroupMembers.get(2).getString(ParseConstants.KEY_FIRST_NAME));\n userInfo2.setText(mGroupMembers.get(2).getString(ParseConstants.KEY_AGE) +\n \" : : \" +\n (mGroupMembers.get(2).getString(ParseConstants.KEY_HOMETOWN)));\n }", "public void updateText()\r\n\t{\r\n\t\tdouble smallest = Math.min(menu.getController().getWidth(), menu.getController().getHeight());\r\n\t\tdouble equivalent12 = smallest/55;//Equivalent of 12 point font on base dimensions\r\n\t\t\r\n\t\ttextRenderer = new TextRenderer(new Font(fontName, Font.PLAIN, (int)(equivalent12*size)), true, true);\r\n\t}", "public void setView4Text(String text){\n view4Text.set(text);\n }", "public void updateView(String message)\n {\n Log.w(\"MainActivity\",\"In updateview: \" + message);\n\n TextView messageTV = findViewById(R.id.messageTextView);\n\n messageTV.setText(message);\n\n }", "public void updateArticleView(ServerObj serverObj){\n View v = getView();\n// String[] data = Ipsum.Articles;\n// article.setText(data[position]);\n// currentPosition = position;\n currentServerObj=serverObj;\n LinearLayout containerOfContents= (LinearLayout) v.findViewById(R.id.container_of_contents);\n containerOfContents.removeAllViews();\n ContentsViewBuilder contentsViewBuilder=new ContentsViewBuilder(activity);\n Log.d(\"myPavilion\",\"serverObj\"+serverObj.getJson());\n View contentsView=contentsViewBuilder.getView(serverObj.getContentsObj());\n containerOfContents.addView(contentsView);\n\n }", "private void setView(LockedDocument doc) {\n\t\ttext1.setText(doc.getTitle());\n\t\ttext2.setText(doc.getContents());\n\t\ttext1.setFocusableInTouchMode(true);\n\t\ttext1.setEnabled(true);\n\t\ttext2.setFocusableInTouchMode(true);\n\t\ttext2.setEnabled(true);\n\t\tlock.setEnabled(false);\n\t\trefresh.setEnabled(false);\n\t\tsave.setEnabled(true);\n\t}", "public void updateUI() {\n\n TextView site1 = (TextView) findViewById(R.id.site1);\n TextView temp1 = (TextView) findViewById(R.id.temp1);\n TextView disc1 = (TextView) findViewById(R.id.discharge1);\n TextView height1 = (TextView) findViewById(R.id.height1);\n\n TextView site2 = (TextView) findViewById(R.id.site2);\n TextView temp2 = (TextView) findViewById(R.id.temp2);\n TextView disc2 = (TextView) findViewById(R.id.discharge2);\n TextView height2 = (TextView) findViewById(R.id.height2);\n\n TextView site3 = (TextView) findViewById(R.id.site3);\n TextView temp3 = (TextView) findViewById(R.id.temp3);\n TextView disc3 = (TextView) findViewById(R.id.discharge3);\n TextView height3 = (TextView) findViewById(R.id.height3);\n\n TextView site4 = (TextView) findViewById(R.id.site4);\n TextView temp4 = (TextView) findViewById(R.id.temp4);\n TextView disc4 = (TextView) findViewById(R.id.discharge4);\n TextView height4 = (TextView) findViewById(R.id.height4);\n\n TextView site5 = (TextView) findViewById(R.id.site5);\n TextView temp5 = (TextView) findViewById(R.id.temp5);\n TextView disc5 = (TextView) findViewById(R.id.discharge5);\n TextView height5 = (TextView) findViewById(R.id.height5);\n\n\n site1.setText(siteNames.get(0));\n tempIndex = 0;\n discIndex = 0;\n heightIndex = 0;\n\n if(!temps.isEmpty()) { //add this to all\n if (r.checkTemp(0)) {\n temp1.setText(\"Temperature: \" + temps.get(tempIndex++));\n temp1.setVisibility(View.VISIBLE);\n }\n }\n\n if(!discharge.isEmpty()) {\n if (r.checkDisc(0)) {\n disc1.setText(\"Water Discharge: \" + discharge.get(discIndex++));\n disc1.setVisibility(View.VISIBLE);\n\n }\n }\n\n if(!heights.isEmpty()){\n if(r.checkHeight(0)){\n height1.setText(\"Water Height: \" + heights.get(heightIndex++));\n height1.setVisibility(View.VISIBLE);\n }\n }\n\n\n\n site2.setText(siteNames.get(1));\n\n if(!temps.isEmpty()) {\n if (r.checkTemp(1)) {\n temp2.setText(\"Temperature: \" + temps.get(tempIndex++));\n temp2.setVisibility(View.VISIBLE);\n }\n }\n if(!discharge.isEmpty()) {\n if (r.checkDisc(1)) {\n disc2.setText(\"Water Discharge: \" + discharge.get(discIndex++));\n disc2.setVisibility(View.VISIBLE);\n }\n }\n\n if(!heights.isEmpty()){\n if(r.checkHeight(1)) {\n if (heights.size() >= 2) {\n height2.setText(\"Water Height: \" + heights.get(heightIndex++));\n height2.setVisibility(View.VISIBLE);\n }\n }\n }\n\n if(numSites >= 3){\n\n site3.setText(siteNames.get(2));\n if(!temps.isEmpty()) {\n if (r.checkTemp(2)) {\n temp3.setText(\"Temperature: \" + temps.get(tempIndex++));\n temp3.setVisibility(View.VISIBLE);\n }\n }\n if(!discharge.isEmpty()) {\n if (r.checkDisc(2)) {\n if (discharge.size() >= 3) {\n disc3.setText(\"Water Discharge: \" + discharge.get(discIndex++));\n disc3.setVisibility(View.VISIBLE);\n }\n }\n }\n if(!heights.isEmpty()){\n if(r.checkHeight(2)) {\n if (heights.size() >= 3) {\n height3.setText(\"Water Height: \" + heights.get(heightIndex++));\n }\n }\n }\n }\n\n if (numSites >= 4) {\n site4.setText(siteNames.get(3));\n site4.setVisibility(View.VISIBLE);\n\n if(!discharge.isEmpty()) {\n if (r.checkDisc(3)) {\n if (discharge.size() >= 4) {\n disc4.setText(\"Water Discharge: \" + discharge.get(discIndex++));\n disc4.setVisibility(View.VISIBLE);\n }\n }\n }\n\n if(!heights.isEmpty()){\n\n if(r.checkHeight(3)) {\n if (heights.size() >= 4) {\n height4.setText(\"Water Height: \" + heights.get(heightIndex++));\n height4.setVisibility(View.VISIBLE);\n }\n }\n }\n if(!temps.isEmpty()) {\n if (r.checkTemp(3)) {\n\n temp4.setText(\"Temperature: \" + temps.get(tempIndex++));\n temp4.setVisibility(View.VISIBLE);\n }\n }\n }\n\n if (numSites == 5) {\n site5.setText(siteNames.get(4));\n site5.setVisibility(View.VISIBLE);\n if (!discharge.isEmpty()) {\n if (r.checkDisc(4)) {\n if(discharge.size() >= 5) {\n disc5.setText(\"Water Discharge: \" + discharge.get(discIndex++));\n disc5.setVisibility(View.VISIBLE);\n }\n }\n }\n if(!heights.isEmpty()){\n if(r.checkHeight(4)) {\n if (heights.size() >= 5) {\n height5.setText(\"Water Height: \" + heights.get(heightIndex++));\n height5.setVisibility(View.VISIBLE);\n }\n }\n }\n if (!temps.isEmpty()) {\n if (r.checkTemp(4)) {\n\n temp5.setText(\"Temperature: \" + temps.get(tempIndex++));\n temp5.setVisibility(View.VISIBLE);\n }\n }\n }\n }", "public void updateView(ClientView view);", "public void setText(String text) {\n\t\tthis.text = text;\n\t\tupdateView();\n\t}", "@Override\n public void onClick(View v) {\n Config.context.entry.delete(0);\n Config.context.entry.delete(1);\n // refresh the TextView\n Config.context.textViewMain.setText(Config.context.entry.readFirst(0));\n Config.context.textViewSecond.setText(Config.context.entry.readFirst(1));\n }", "private void refreshInformation () {\n if (textInformation != null) {\n String messageInfo = \"\";\n\n while (!listMessageInfo.isEmpty()) {\n messageInfo = listMessageInfo.getLast() + \"\\n\" + messageInfo;\n listMessageInfo.removeLast();\n }\n\n if (textInformation.getText() != null) {\n textInformation.setText(messageInfo + textInformation.getText());\n } else {\n textInformation.setText(messageInfo);\n }\n }\n }", "@Override\n\t\t\tpublic void setTextView(String str) {\n\t\t\t\t\n\t\t\t}", "private void updateUI() {\n Bite bite = BiteLab.get(getActivity()).getBite(mBiteId);\n\n mPlacementTextView.setText(bite.getPlacement());\n\n Calendar c = bite.getCalendar();\n int year = c.get(Calendar.YEAR);\n int month = c.get(Calendar.MONTH)+1;\n int day = c.get(Calendar.DAY_OF_MONTH);\n mDateTextView.setText(getString(R.string.show_date, day, month, year));\n\n mDaysSinceBiteTextView.setText(getString(R.string.days_since_bite\n , bite.getDaysSinceBite()));\n\n mStageTextView.setText(getString(R.string.show_stage, bite.getStage()));\n }", "private void viewExtractedData() {\n txtViewer.setText(extractedData);\n }", "public void onClick(View v) {\n \tsetTxtViews();\n }", "public void notifyViewers() {\n\t\tfor (DrawingView view : views) {\n\t\t\tview.notify(this);\n\t\t}\n\n\t\tfor (DrawingView textViewer : textViews) {\n\t\t\ttextViewer.notify(this);\n\t\t}\n\t}", "public void updateForRecyclerView(CharSequence text, int futureTextViewWidth, int expandState){\n mFutureTextViewWidth = futureTextViewWidth;\n mCurrState = expandState;\n setText(text);\n }", "public void update()\n\t{\n\t\tsetFont(attribs.getFont());\n\t\tTextMeshGenerator.generateTextVao(this.text, this.attribs, this.font, this.mesh);\n\t\tsize = new Vector2f(mesh.maxPoint.x(), mesh.maxPoint.y());\n\t}", "public void updateAnswer(String text) {\n\t\tclearAnswer();\n\t\t\n\t\t// Add new label with the string\n\t\tlbl.setText(text);\n\t\tvPanel.add(lbl);\n\n\t\treturn;\n\t}", "protected void updateDisplays() {\n \trecordDisplay.setText(formatField());\n \tif(updated) {\n \t\trecordDisplay.setFont(regularFont);\n \t} else {\n \t\trecordDisplay.setFont(italicFont);\n \t}\n }", "private void updateListView() {\n ArrayAdapter<String> adapter = new ArrayAdapter<String>(this, R.layout.textview, geofences);\n ListView list = (ListView) findViewById(R.id.listView);\n list.setAdapter(adapter);\n }", "@Test\n public void ensureTextChangesWork(){\n onView(withId(R.id.placeEditText)).perform(typeText(\"London\"));\n\n // Check that the language text was changed.\n onView(withId(R.id.languageEditText)).perform(typeText(\"It\"));\n\n // Check that the language text was changed.\n onView(withId(R.id.maxrowsEditText)).perform(typeText(\"3\"));\n\n // check button click\n onView(withId(R.id.button)).perform(click());\n\n // check returned list view\n onView(withId(R.id.listViewResult)).check(matches(isDisplayed()));\n }", "public void resetText(View view) {\n display();\n }", "private void updateLabelText() {\n /*\n r18 = this;\n android.view.View r13 = r18.getNativeView()\n android.widget.TextView r13 = (android.widget.TextView) r13\n if (r13 != 0) goto L_0x0009\n L_0x0008:\n return\n L_0x0009:\n boolean r7 = r18.isSingleLine()\n r0 = r18\n float r0 = r0.minimumFontSizeInPixels\n r16 = r0\n r17 = 1036831949(0x3dcccccd, float:0.1)\n int r16 = (r16 > r17 ? 1 : (r16 == r17 ? 0 : -1))\n if (r16 < 0) goto L_0x00f6\n r3 = 1\n L_0x001b:\n r8 = r3\n r13.setSingleLine(r7)\n r0 = r18\n int r0 = r0.viewHeightInLines\n r16 = r0\n if (r16 <= 0) goto L_0x00f9\n r0 = r18\n int r0 = r0.viewHeightInLines\n r16 = r0\n r0 = r16\n r13.setLines(r0)\n L_0x0032:\n if (r7 == 0) goto L_0x0102\n r16 = 1\n r0 = r16\n r13.setMaxLines(r0)\n L_0x003b:\n r0 = r18\n java.lang.CharSequence r11 = r0.originalText\n if (r11 != 0) goto L_0x0135\n android.text.SpannableStringBuilder r11 = new android.text.SpannableStringBuilder\n java.lang.String r16 = \"\"\n r0 = r16\n r11.<init>(r0)\n r12 = r11\n L_0x004b:\n if (r8 == 0) goto L_0x0132\n int r16 = r12.length()\n if (r16 <= 0) goto L_0x0132\n r2 = 0\n L_0x0054:\n int r16 = r12.length()\n r0 = r16\n if (r2 >= r0) goto L_0x006c\n char r10 = r12.charAt(r2)\n r16 = 13\n r0 = r16\n if (r10 == r0) goto L_0x006c\n r16 = 10\n r0 = r16\n if (r10 != r0) goto L_0x012b\n L_0x006c:\n int r16 = r12.length()\n r0 = r16\n if (r2 >= r0) goto L_0x0132\n android.text.SpannableStringBuilder r11 = new android.text.SpannableStringBuilder\n r16 = 0\n r0 = r16\n r11.<init>(r12, r0, r2)\n L_0x007d:\n boolean r0 = r11 instanceof android.text.Spannable\n r16 = r0\n if (r16 != 0) goto L_0x0089\n android.text.SpannableStringBuilder r12 = new android.text.SpannableStringBuilder\n r12.<init>(r11)\n r11 = r12\n L_0x0089:\n r1 = 0\n r0 = r18\n int r0 = r0.autoLinkFlags\n r16 = r0\n if (r16 == 0) goto L_0x00a0\n r16 = r11\n android.text.Spannable r16 = (android.text.Spannable) r16\n r0 = r18\n int r0 = r0.autoLinkFlags\n r17 = r0\n boolean r1 = android.text.util.Linkify.addLinks(r16, r17)\n L_0x00a0:\n if (r1 == 0) goto L_0x012f\n android.text.method.MovementMethod r9 = android.text.method.LinkMovementMethod.getInstance()\n L_0x00a6:\n android.text.method.MovementMethod r16 = r13.getMovementMethod()\n r0 = r16\n if (r9 == r0) goto L_0x00c6\n boolean r5 = r13.isFocusable()\n boolean r4 = r13.isClickable()\n boolean r6 = r13.isLongClickable()\n r13.setMovementMethod(r9)\n r13.setFocusable(r5)\n r13.setClickable(r4)\n r13.setLongClickable(r6)\n L_0x00c6:\n r0 = r18\n android.text.TextUtils$TruncateAt r14 = r0.ellipsize\n if (r9 == 0) goto L_0x00da\n android.text.TextUtils$TruncateAt r16 = android.text.TextUtils.TruncateAt.START\n r0 = r16\n if (r14 == r0) goto L_0x00d8\n android.text.TextUtils$TruncateAt r16 = android.text.TextUtils.TruncateAt.MIDDLE\n r0 = r16\n if (r14 != r0) goto L_0x00da\n L_0x00d8:\n android.text.TextUtils$TruncateAt r14 = android.text.TextUtils.TruncateAt.END\n L_0x00da:\n r13.setEllipsize(r14)\n android.text.TextUtils$TruncateAt r16 = android.text.TextUtils.TruncateAt.MARQUEE\n r0 = r16\n if (r14 != r0) goto L_0x00ea\n r16 = 1\n r0 = r16\n r13.setSelected(r0)\n L_0x00ea:\n android.widget.TextView$BufferType r16 = android.widget.TextView.BufferType.NORMAL\n r0 = r16\n r13.setText(r11, r0)\n r13.requestLayout()\n goto L_0x0008\n L_0x00f6:\n r3 = 0\n goto L_0x001b\n L_0x00f9:\n r16 = 0\n r0 = r16\n r13.setMinLines(r0)\n goto L_0x0032\n L_0x0102:\n r0 = r18\n int r0 = r0.maxLines\n r16 = r0\n if (r16 <= 0) goto L_0x0129\n r0 = r18\n int r15 = r0.maxLines\n L_0x010e:\n r0 = r18\n int r0 = r0.viewHeightInLines\n r16 = r0\n if (r16 <= 0) goto L_0x0124\n r0 = r18\n int r0 = r0.viewHeightInLines\n r16 = r0\n r0 = r16\n if (r15 <= r0) goto L_0x0124\n r0 = r18\n int r15 = r0.viewHeightInLines\n L_0x0124:\n r13.setMaxLines(r15)\n goto L_0x003b\n L_0x0129:\n r15 = 1\n goto L_0x010e\n L_0x012b:\n int r2 = r2 + 1\n goto L_0x0054\n L_0x012f:\n r9 = 0\n goto L_0x00a6\n L_0x0132:\n r11 = r12\n goto L_0x007d\n L_0x0135:\n r12 = r11\n goto L_0x004b\n */\n throw new UnsupportedOperationException(\"Method not decompiled: p006ti.modules.titanium.p007ui.widget.TiUILabel.updateLabelText():void\");\n }", "private void updateText()\n\t{\n\t\tlong longResult;\t\t//holds the value of result casted to type long\n\t\tif(result % 1 == 0)\n\t\t{\n\t\t\tlongResult = (long)result;\n\t\t\tupdateText += longResult;\n\t\t}\n\t\telse\n\t\t{\n\t\t\tupdateText += result;\n\t\t}\n\t\tentry.setText (\"\");\n\t\tentry.setText (updateText);\n\t\tupdateText = \"\";\n\t\tentry.grabFocus();\n\t}", "private void setText(Text text) {\n \t\tthis.text = text;\n \t}", "@Override\r\n\t\tpublic void updateUI() {\n\t\t\tif(deparments != null){\r\n\r\n\t\t\t\ttv.setText(deparments.toString());\r\n\t\t\t}else{\r\n\t\t\t\tSystem.out.println(\"deparments \"+deparments.toString());\r\n\t\t\t}\r\n\t\t}", "public void update() {\n\n\t\tdisplay();\n\t}", "@Override\n public void run() {\n receivedTextView6.setText(str5);\n receivedTextView5.setText(str4);\n receivedTextView4.setText(str3);\n receivedTextView3.setText(str2);\n receivedTextView2.setText(str1);\n receivedTextView1.setText(str0);\n }", "void setText(int offset, int length, String newText)\n\t{\n\t}", "private void updateText(final String info, final String caller) {\n\t\trunOnUiThread(new Runnable() {\n\t\t\tpublic void run() {\n\n\t\t\t\tinfoText.setText(info);\n\t\t\t\tcallerText.setText(caller);\n\t\t\t}\n\t\t});\n\t}", "final void updateSpan(){\n setEdited();\n if (this instanceof Document){\n ((Document)this).updateDoc();\n } else {\n getParent().updateParent();\n }\n }", "void updateControls();", "@Override\n public void updateView(Message msg)\n {\n \n }", "void updateViewFromModel();", "public void read() {\n\n Object[][] obj = readItems();\n\n for (View v : views) {\n v.update(obj);\n }\n }", "private void updateDateAndTimeTextView(Calendar instance) {\n\t\tmCalendar = instance;\n\n\t\t// update the dateText view with the corresponding date\n\t\tbtUpdateDateAndHour.setText(android.text.format.DateFormat\n\t\t\t\t.getDateFormat(this).format(mCalendar.getTime())\n\t\t\t\t+ \" \"\n\t\t\t\t+ functions.getTimeFromDate(mCalendar.getTime()));\n\t}", "private void setTextToViewList(CharSequence charSequence) {\n CopyOnWriteArrayList<NetworkSpeedView> copyOnWriteArrayList = this.mViewList;\n if (copyOnWriteArrayList != null) {\n Iterator<NetworkSpeedView> it = copyOnWriteArrayList.iterator();\n while (it.hasNext()) {\n it.next().setText(charSequence);\n }\n }\n }", "public void updateBook(View view){\n update();\n }", "public void updateContent() {\n\t\t\n\t\tupdateResidencias();\n\t\tupdateUniversidades();\n\t\t\n\t}", "public void update() {\r\n\t\t\tsetTextValue(updateNoteEnabled);\r\n\t\t}" ]
[ "0.7581997", "0.73927504", "0.73272306", "0.7250001", "0.7049791", "0.7020753", "0.6960249", "0.68160355", "0.68160355", "0.6747407", "0.6672468", "0.66347927", "0.6599015", "0.6569213", "0.6529846", "0.6479389", "0.6472587", "0.6472277", "0.6466752", "0.6456758", "0.6436409", "0.6406656", "0.6402921", "0.6386983", "0.6382733", "0.63684225", "0.6360751", "0.6310804", "0.6291115", "0.62562776", "0.6240929", "0.62327236", "0.62283176", "0.62271994", "0.6223129", "0.61930215", "0.61749566", "0.61638266", "0.6161555", "0.6148728", "0.61336607", "0.6121108", "0.6109972", "0.6109522", "0.6105992", "0.6097841", "0.60955167", "0.6061448", "0.6059068", "0.60175496", "0.60158813", "0.60141736", "0.6004638", "0.599041", "0.5988065", "0.5979396", "0.5972164", "0.5951263", "0.5949094", "0.59363186", "0.5933651", "0.5929806", "0.589489", "0.5893874", "0.5892652", "0.5875732", "0.5872596", "0.58666897", "0.586434", "0.5837316", "0.58190817", "0.5814122", "0.58048373", "0.5791108", "0.57884294", "0.578479", "0.5780644", "0.5772785", "0.57708305", "0.57698125", "0.5760812", "0.57504034", "0.57501316", "0.57459885", "0.57451123", "0.5744692", "0.57426566", "0.5742554", "0.5734617", "0.5733278", "0.5732724", "0.5724877", "0.57229453", "0.572257", "0.57179815", "0.5716834", "0.5716608", "0.57142484", "0.57112926", "0.5709826" ]
0.657746
13
Checks if the user input has been valid. The input is okay if at least the minimum data has been entered Required data for valid input: date, time, amount, stress, tired and glucose begin Checkboxes are not required because they are default set to false.
private boolean isInputOkay() { // checks the text fields if (mBinding.date.getText() == null || mBinding.date.getText().toString().equals("")) { snackBar("Please select the date."); return false; } if (mBinding.time.getText() == null || mBinding.time.getText().toString().equals("")) { snackBar("Please select the time."); return false; } if (mBinding.stress.getText() == null || mBinding.stress.getText().toString().equals("")) { snackBar("Please select the stress level."); return false; } if (mBinding.tired.getText() == null || mBinding.tired.getText().toString().equals("")) { snackBar("Please select the tiredness level."); return false; } if (mBinding.mv0.getText() == null || mBinding.mv0.getText().toString().equals("")) { snackBar("Please select at least the start glucose value."); return false; } return true; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public boolean checkEntryInputs() {\n\t\tboolean isValid = true;\n\t\tif(sampleNumberTF.getText().equals(\"\")) {\n\t\t\tisValid = false;\n\t\t}\n\t\t\n\t\tif(materialDescriptionTF.getText().equals(\"\")) {\n\t\t\tisValid = false;\n\t\t}\n\t\t\n\t\tif(Double.valueOf(bacteroidesConcentrationTF.getText())==null) {\n\t\t\tisValid = false;\n\t\t}\n\t\treturn isValid;\n\t}", "private boolean checkInputFields(){\r\n\t\tString allertMsg = \"Invalid input: \" + System.getProperty(\"line.separator\");\r\n\t\t\r\n\t\t//Check input for MCS text field\r\n\t\ttry{\r\n\t\t\tFloat testValue = Float.parseFloat(m_MCSTf.getText());\r\n\t\t\tif(testValue < 0 || testValue > 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a number between 0 and 1 as a MCS score.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\t//Check input for relevance score weight and coherence score weight text fields\r\n\t\ttry{\r\n\t\t\tFloat relScoreW = Float.parseFloat(m_RelScoreTf.getText());\r\n\t\t\tFloat cohScoreW = Float.parseFloat(m_CohScoreTf.getText());\r\n\t\t\tif(relScoreW < 0 || relScoreW > 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t\tif(cohScoreW < 0 || cohScoreW > 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t\tif((relScoreW + cohScoreW) != 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a number between 0 and 1 as a weight for relevance and coherence score.\" + System.getProperty(\"line.separator\");\r\n\t\t\tallertMsg += \"Sum of the weights for relevance and coherence score must be 1.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\t//Check input for MCS text field\r\n\t\ttry{\r\n\t\t\tFloat testValue = Float.parseFloat(m_KeyTf.getText());\r\n\t\t\tif(testValue < 0)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number as multiplier for keyword concepts.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\t//Check input for category confidence weight\r\n\t\ttry{\r\n\t\t\tFloat testValue = Float.parseFloat(m_CatConfTf.getText());\r\n\t\t\tif(testValue < 0)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number as a weight for the weight of the category confidence of concepts.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\t//Check input for weight of repeated concepts\r\n\t\ttry{\r\n\t\t\tFloat testValue = Float.parseFloat(m_RepeatTf.getText());\r\n\t\t\tif(testValue < 0)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number as a weight for repeated concepts.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\t//Check input for number of output categories\r\n\t\ttry{\r\n\t\t\tInteger testValue = Integer.parseInt(m_MaxCatsTf.getText());\r\n\t\t\tif(testValue < 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number for the maximum number of output categories.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\ttry{\r\n\t\t\tInteger testValue = Integer.parseInt(m_MinCatsTf.getText());\r\n\t\t\tif(testValue < 1)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number for the minimum number of output categories.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\ttry{\r\n\t\t\tFloat testValue = Float.parseFloat(m_MinCatScoreTf.getText());\r\n\t\t\tif(testValue < 0.0f || testValue > 1.0f)\r\n\t\t\t\tthrow new NumberFormatException();\r\n\t\t}catch (NumberFormatException e){\r\n\t\t\tallertMsg += \"Please enter a positive number between 0 and 1 as minimum category score.\" + System.getProperty(\"line.separator\");\r\n\t\t}\r\n\t\tif(allertMsg.length() > 18){\r\n\t\t\tAlert alert = new Alert(AlertType.ERROR);\r\n\t\t\talert.setContentText(allertMsg);\r\n\t\t\talert.showAndWait();\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\treturn true;\r\n\t}", "private boolean checkInputValidity() {\n // if any of the input field is empty, return false directly\n if (name.getText().equals(\"\") || id.getText().equals(\"\") || fiber.getText().equals(\"\")\n || protein.getText().equals(\"\") || fat.getText().equals(\"\") || calories.getText().equals(\"\")\n || carbohydrate.getText().equals(\"\")) {\n String message = \"Make sure enter the value of all nutrient components, please try again!\";\n // display the warning windows with the assigned warning message\n Alert alert = new Alert(AlertType.INFORMATION, message);\n alert.getDialogPane().setMinHeight(Region.USE_PREF_SIZE);\n this.close();// close the add food stage\n alert.showAndWait().filter(response -> response == ButtonType.OK);\n return false;\n }\n // if any nutrition info input is not a number value or is negative, return false directly\n try {\n Double fibervalue = null;\n Double proteinvalue = null;\n Double fatvalue = null;\n Double caloriesvalue = null;\n Double carbohydratevalue = null;\n // trim the input to exact numeric value\n fibervalue = Double.valueOf(fiber.getText().trim());\n proteinvalue = Double.valueOf(protein.getText().trim());\n fatvalue = Double.valueOf(fat.getText().trim());\n caloriesvalue = Double.valueOf(calories.getText().trim());\n carbohydratevalue = Double.valueOf(carbohydrate.getText().trim());\n // nutrition input is suppose to be positive numbers\n // if any of the numbers is negative, return false diretcly\n if (fibervalue < 0.0 || proteinvalue < 0.0 || fatvalue < 0.0 || caloriesvalue < 0.0\n || carbohydratevalue < 0.0) {\n String message = \"The input of the nutrient can not be negative, please try again!\";\n Alert alert = new Alert(AlertType.INFORMATION, message);\n alert.getDialogPane().setMinHeight(Region.USE_PREF_SIZE);\n this.close();\n alert.showAndWait().filter(response -> response == ButtonType.OK);\n return false;\n }\n // if any input of the nutrition info is not a double value, catch the exception and return\n // false\n } catch (Exception e) {\n String message =\n \"At least one nutrition value input is invalid, please type a number in nutrient textbox!\";\n // display the warning windows with the assigned warning message\n Alert alert = new Alert(AlertType.INFORMATION, message);\n alert.getDialogPane().setMinHeight(Region.USE_PREF_SIZE);\n this.close(); // close the addfood stage\n // wait for response from ok button\n alert.showAndWait().filter(response -> response == ButtonType.OK);\n return false;\n }\n return true;\n }", "private boolean validateInputs() {\n return !proID.getText().isEmpty() || \n !proName.getText().isEmpty() ||\n !proPrice.getText().isEmpty();\n }", "@Override\n\t@FXML\n\tpublic boolean validate() {\n\t\t\n\t\tboolean isDataEntered = true;\n\t\tLocalDate startDate = Database.getInstance().getStartingDate();\n\t\tSystem.out.println();\n\t\tif(amountField.getText() == null || amountField.getText().trim().isEmpty())\n\t\t\tisDataEntered = setErrorTxt(\"You left the amount field empty.\");\n\t\telse if(!(Validation.validateAmount(amountField.getText())))\n\t\t\tisDataEntered = setErrorTxt(\"Please enter a valid amount\");\n\t\telse if(creditTextField.getText() == null || creditTextField.getText().trim().isEmpty())\n\t\t\tisDataEntered = setErrorTxt(\"You left the credit text field empty.\");\n\t\telse if(!(Validation.validateChars(creditTextField.getText())))\n\t\t\tisDataEntered = setErrorTxt(\"Please only enter valid characters\");\n\t\telse if(dateField.getValue() == null) {\n\t\t\tisDataEntered = setErrorTxt(\"You left the date field empty.\");\t\t\t\n\t\t}\n\t\telse if(dateField.getValue().isBefore(startDate))\n\t\t\tisDataEntered = setErrorTxt(\"Sorry, the date you entered is before the starting date.\");\n\t\treturn isDataEntered;\n\t}", "private boolean validateInputs() {\n if (Constants.NULL.equals(review)) {\n reviewET.setError(\"Must type a review!\");\n reviewET.requestFocus();\n return false;\n }\n if (Constants.NULL.equals(heading)) {\n headingET.setError(\"Heading cannot be empty\");\n headingET.requestFocus();\n return false;\n }\n return true;\n }", "private boolean Validate() {\n EditText titleText = findViewById(R.id.register_movie_title_txt);\n EditText yearText = findViewById(R.id.register_movie_year_txt);\n EditText ratingText = findViewById(R.id.register_movie_rating_txt);\n\n\n boolean is_filled_required_fields = false;\n is_filled_required_fields = titleText.getText().toString().length() > 0\n && yearText.getText().toString().length() > 0\n && ratingText.getText().toString().length() > 0;\n\n if (!is_filled_required_fields) {\n Snackbar mySnackbar = Snackbar.make(findViewById(R.id.activity_register_base_layout), \"Please fill required fields\", BaseTransientBottomBar.LENGTH_SHORT);\n mySnackbar.show();\n }\n return is_filled_required_fields;\n }", "private void checkFields() {\n if (month.getText().toString().isEmpty()) {\n month.setError(\"enter a month\");\n month.requestFocus();\n return;\n }\n if (day.getText().toString().isEmpty()) {\n day.setError(\"enter a day\");\n day.requestFocus();\n return;\n }\n if (year.getText().toString().isEmpty()) {\n year.setError(\"enter a year\");\n year.requestFocus();\n return;\n }\n if (hour.getText().toString().isEmpty()) {\n hour.setError(\"enter an hour\");\n hour.requestFocus();\n return;\n }\n if (minute.getText().toString().isEmpty()) {\n minute.setError(\"enter the minute\");\n minute.requestFocus();\n return;\n }\n if (AMorPM.getText().toString().isEmpty()) {\n AMorPM.setError(\"enter AM or PM\");\n AMorPM.requestFocus();\n return;\n }\n if (place.getText().toString().isEmpty()) {\n place.setError(\"enter the place\");\n place.requestFocus();\n return;\n }\n }", "public boolean validateInputFields(){\n if(titleText.getText().isEmpty() || descriptionText.getText().isEmpty()){\n showError(true, \"All fields are required. Please complete.\");\n return false;\n }\n if(locationCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a location.\");\n return false;\n }\n if(contactCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a contact.\");\n return false;\n }\n if(typeCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select the type.\");\n return false;\n }\n if(customerCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a customer.\");\n return false;\n }\n if(userCombo.getSelectionModel().isEmpty()){\n showError(true, \"Please select a user.\");\n return false;\n }\n return true;\n }", "public boolean inputIsValid() {\n return nameIsValid() &&\n descriptionIsValid() &&\n priceIsValid() &&\n streetIsValid() &&\n zipcodeIsValid() &&\n cityIsValid() &&\n imageIsSelected();\n }", "public boolean validateForm() {\r\n\t\tint validNum;\r\n\t\tdouble validDouble;\r\n\t\tString lengthVal = lengthInput.getText();\r\n\t\tString widthVal = widthInput.getText();\r\n\t\tString minDurationVal = minDurationInput.getText();\r\n\t\tString maxDurationVal = maxDurationInput.getText();\r\n\t\tString evPercentVal = evPercentInput.getText();\r\n\t\tString disabilityPercentVal = disabilityPercentInput.getText();\r\n\t\t\r\n\t\t/**\r\n\t\t * Step.1 - Ensure all inputs are numbers\r\n\t\t */\r\n\t\t\r\n\t\t// Try to parse length as int\r\n\t\ttry {\r\n\t\t\tvalidNum = Integer.parseInt(lengthVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"Length must be an integer\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t// Try to parse width as int\r\n\t\ttry {\r\n\t\t\tvalidNum = Integer.parseInt(widthVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"Width must be an integer\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t// Try to parse width as int\r\n\t\ttry {\r\n\t\t\tvalidNum = Integer.parseInt(minDurationVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"Min Duration must be an integer\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t// Try to parse width as int\r\n\t\ttry {\r\n\t\t\tvalidNum = Integer.parseInt(maxDurationVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"Max Duration must be an integer\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t// Try to parse width as int\r\n\t\ttry {\r\n\t\t\tvalidDouble = Double.parseDouble(evPercentVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"EV % must be a number\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t// Try to parse width as int\r\n\t\ttry {\r\n\t\t\tvalidDouble = Double.parseDouble(disabilityPercentVal);\r\n\t } catch (NumberFormatException e) {\r\n\t \tsetErrorMessage(\"Disability % must be a number\");\r\n\t return false;\r\n\t }\r\n\t\t\r\n\t\t/**\r\n\t\t * Step.2 - Ensure all needed inputs are non-zero\r\n\t\t */\r\n\t\t\r\n\t\tvalidNum = Integer.parseInt(lengthVal);\r\n\t\tif (validNum <= 0) {\r\n\t\t\tsetErrorMessage(\"Length must be greater than 0\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tvalidNum = Integer.parseInt(widthVal);\r\n\t\tif (validNum <= 0) {\r\n\t\t\tsetErrorMessage(\"Width must be greater than 0\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tvalidNum = Integer.parseInt(minDurationVal);\r\n\t\tif (validNum < 10) {\r\n\t\t\tsetErrorMessage(\"Min Duration must be at least 10\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tvalidNum = Integer.parseInt(maxDurationVal);\r\n\t\tif (validNum < 10) {\r\n\t\t\tsetErrorMessage(\"Max Duration must be at least 10\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tvalidDouble = Double.parseDouble(evPercentVal);\r\n\t\tif (validDouble < 0) {\r\n\t\t\tsetErrorMessage(\"EV % can't be less than 0\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tvalidDouble = Double.parseDouble(disabilityPercentVal);\r\n\t\tif (validDouble < 0) {\r\n\t\t\tsetErrorMessage(\"Disability % can't be less than 0\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\t/**\r\n\t\t * Step.3 - Ensure Max Duration can't be smaller than Min Duration\r\n\t\t */\r\n\t\t\r\n\t\tif (Integer.parseInt(minDurationVal) > Integer.parseInt(maxDurationVal)) {\r\n\t\t\tsetErrorMessage(\"Max Duration can't be less than Min Duration\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\t/**\r\n\t\t * Step.4 - Ensure values aren't too large for the system to handle\r\n\t\t */\r\n\t\t\r\n\t\tif (Integer.parseInt(lengthVal) > 15) {\r\n\t\t\tsetErrorMessage(\"Carpark length can't be greater than 15 spaces\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\r\n\t\tif (Integer.parseInt(widthVal) > 25) {\r\n\t\t\tsetErrorMessage(\"Carpark width can't be greater than 25 spaces\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\tif (Integer.parseInt(minDurationVal) > 150) {\r\n\t\t\tsetErrorMessage(\"Min Duration can't be greater than 150\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tif (Integer.parseInt(maxDurationVal) > 300) {\r\n\t\t\tsetErrorMessage(\"Max Duration can't be greater than 300\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tif (Double.parseDouble(evPercentVal) > 100) {\r\n\t\t\tsetErrorMessage(\"EV % can't be greater than 100\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tif (Double.parseDouble(disabilityPercentVal) > 100) {\r\n\t\t\tsetErrorMessage(\"Disability % can't be greater than 100\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\tif (Integer.parseInt(minDurationVal) > 150) {\r\n\t\t\tsetErrorMessage(\"Min Duration can't be greater than 150\");\r\n\t\t\treturn false;\r\n\t\t}\r\n\t\t\r\n\t\treturn true;\r\n\t}", "private boolean verifyObligedFields() {\n if(label.getText().toString().isEmpty() || label.getText().toString().equals(\"\"))\n {\n Toast.makeText(ExpenseCardViewDetails.this, R.string.label_must_be_filled, Toast.LENGTH_SHORT).show();\n return false;\n }\n if(category.getSelectedItem().toString().isEmpty())\n {\n Toast.makeText(ExpenseCardViewDetails.this, R.string.category_must_be_filled, Toast.LENGTH_SHORT).show();\n return false;\n }\n if(cost.getText().toString().isEmpty()){\n Toast.makeText(ExpenseCardViewDetails.this, R.string.cost_must_be_filled, Toast.LENGTH_SHORT).show();\n return false;\n }\n if(dateDue.getText().toString().isEmpty()){\n Toast.makeText(ExpenseCardViewDetails.this, R.string.date_due_must_be_filled, Toast.LENGTH_SHORT).show();\n return false;\n }\n return true;\n }", "public boolean checkInput(){\n if(spelerIDField.getText().equals(\"\") || typeField.getText().equals(\"\") || codeField.getText().equals(\"\") || heeftBetaaldField.getText().equals(\"\")){\n return true;\n } else { return false; }\n }", "private boolean validateData() {\n if (!mCommon.validateData()) return false;\n\n Core core = new Core(this);\n\n // Due Date is required\n if (TextUtils.isEmpty(getRecurringTransaction().getDueDateString())) {\n core.alert(R.string.due_date_required);\n return false;\n }\n\n if (TextUtils.isEmpty(mCommon.viewHolder.dateTextView.getText().toString())) {\n core.alert(R.string.error_next_occurrence_not_populate);\n\n return false;\n }\n\n // Payments Left must have a value\n if (getRecurringTransaction().getPaymentsLeft() == null) {\n core.alert(R.string.payments_left_required);\n return false;\n }\n return true;\n }", "private boolean validateInput(){\n Window owner=root.getScene().getWindow();\n inputFileds.addAll(txtfn,txtln,txtsurname,txtDOB,txtResidence,txtMobile,txtID,username);\n for (TextField textField : inputFileds) {\n if(textField.getText().isEmpty()){\n //set css stroke\n Dialog.showMessageDialog(owner,\"Missing Details\",\"Invalid Input\",DialogIcon.WARNING);\n textField.requestFocus();\n return false;\n }\n }\n inputFileds.removeAll(txtDOB,txtMobile,username);\n for (TextField textField : inputFileds) {\n if(textField.getText().length()>30){\n //set css stroke\n Dialog.showMessageDialog(owner,\"Sorry the text you entered can not be greater that 30 characters\",\"Text too Long\",DialogIcon.WARNING);\n textField.requestFocus();\n return false;\n }\n }\n if(username.getText().length()>20 || username.getText().length()<4){\n Dialog.showMessageDialog(owner, \"Sorry your Username has to be More than 3 Characters and can not Exceed 20 Charchaters\", \"Invalid input\",DialogIcon.WARNING);\n username.requestFocus();\n return false;\n }\n if(pass.getText().isEmpty()){\n Dialog.showMessageDialog(owner,\"Missing Details\",\"Invalid Input\",DialogIcon.WARNING);\n pass.requestFocus();\n return false;\n }\n if(pass.getText().length()>20 || pass.getText().length()<4){\n Dialog.showMessageDialog(owner, \"Sorry your Password has to be More than 3 Characters and can not Exceed 20 Charchaters\", \"Invalid Input\",DialogIcon.WARNING);\n pass.requestFocus();\n return false;\n }\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"dd/MM/yyyy\");\n SimpleDateFormat yearFormat = new SimpleDateFormat(\"yyyy\");\n try {\n date = dateFormat.parse(txtDOB.getText());\n Calendar cal=Calendar.getInstance();\n int year=Integer.parseInt(yearFormat.format(date));\n if (year <= 1900 || year>cal.get(Calendar.YEAR)) {\n Dialog.showMessageDialog(owner,\"Invalid Date of Birth\", \"Invalid Input\",DialogIcon.WARNING);\n txtDOB.requestFocus();\n return false;\n }\n String initialEntry=txtDOB.getText();\n String parsedValue=dateFormat.format(date);\n if(!initialEntry.equals(parsedValue)){\n Dialog.showMessageDialog(owner, \"Note your Date of Birth has been corrected\", \"Date Corrected\",DialogIcon.INFORMATION);\n }\n txtDOB.setText(dateFormat.format(date));\n } catch (ParseException ex) {\n Dialog.showMessageDialog(owner,\"Invalid Date of Birth\", \"Invalid Input\",DialogIcon.WARNING);\n txtDOB.requestFocus();\n return false;\n }\n try {\n int mobile=Integer.parseInt(txtMobile.getText());\n } catch (NumberFormatException e) {\n Dialog.showMessageDialog(owner, \"Invalid Mobile Number\", \"Invalid data\",DialogIcon.WARNING);\n txtMobile.requestFocus();\n return false;\n }\n if(txtMobile.getText().length() != 10){\n Dialog.showMessageDialog(owner, \"Sorry your Mobile Number is invalid\", \"Invalid input\",DialogIcon.WARNING);\n txtMobile.requestFocus();\n return false;\n }\n String sql=\"select Username,Password from users where Username=?\";\n try(PreparedStatement prstmt=con.prepareStatement(sql)) {\n prstmt.setString(1, username.getText());\n ResultSet rs=prstmt.executeQuery();\n if(rs.next()){\n Dialog.showMessageDialog(owner, \"Sorry Username already exists\\n Please change to different Username\", \"Username Exists\",DialogIcon.WARNING);\n username.requestFocus();\n return false;\n }\n rs.close();\n } catch (SQLException e) {\n System.err.println(e);\n }\n return true;\n }", "private boolean isInputValid(){\n\t\tString errorMessage = \"\";\n\t\tif((nameField.getText() == null) || (nameField.getText().length() == 0)){\n\t\t\terrorMessage += \"No valid product name!\\n\";\n\t\t}\n\t\tif((amountAvailableField.getText() == null) || (amountAvailableField.getText().length() == 0)){\n\t\t\terrorMessage += \"No valid amount available value!\\n\";\n\t\t}\n\t\tif((amountSoldField.getText() == null) || (amountSoldField.getText().length() == 0)){\n\t\t\terrorMessage += \"No valid amount sold value!\\n\";\n\t\t}\n\t\tif((priceEachField.getText() == null) || (priceEachField.getText().length() == 0)){\n\t\t\terrorMessage += \"No valid price for each!\\n\";\n\t\t}\n\t\tif((priceMakeField.getText() == null) || (priceMakeField.getText().length() == 0)){\n\t\t\terrorMessage += \"No valid price to make the product!\\n\";\n\t\t}\n\t\tif(errorMessage.length() == 0){\n\t\t\treturn true;\n\t\t}\n\t\telse{\n\t\t\treturn false;\n\t\t}\n\t}", "private boolean validateInputs() {\n question = txtQuestion.getText().trim();\n option1 = txtOption1.getText().trim();\n option2 = txtOption2.getText().trim();\n option3 = txtOption3.getText().trim();\n option4 = txtOption4.getText().trim();\n correctOption = jcCorrectAns.getSelectedItem().toString();\n //System.out.println(correctOption);\n if(question.isEmpty() || option1.isEmpty() || option2.isEmpty() || \n option3.isEmpty() || option4.isEmpty() || correctOption.isEmpty()){\n return false;\n }\n return true;\n }", "private boolean checkUserInputValidity() {\n // Extract Student information from the edit text views\n String studentName = mStudentNameEditText.getText().toString().trim();\n String studentGradeString = mStudentGradeEditText.getText().toString();\n\n // Check for valid student name\n if (TextUtils.isEmpty(studentName)) {\n Toast.makeText(this, R.string.please_enter_valid_name, Toast.LENGTH_SHORT).show();\n mStudentNameEditText.requestFocus();\n return false;\n }\n\n // Check for valid student birthdate\n if (mStudentBirthdate == 0) {\n Toast.makeText(this, R.string.please_enter_valid_birthdate,\n Toast.LENGTH_SHORT).show();\n return false;\n }\n if (DateUtils.isChosenDateAfterToday(mStudentBirthdate)) {\n Toast.makeText(this, R.string.please_enter_valid_birthdate,\n Toast.LENGTH_SHORT).show();\n return false;\n }\n\n // Check for valid student grade\n if (TextUtils.isEmpty(studentGradeString)) {\n Toast.makeText(this, R.string.please_enter_valid_grade, Toast.LENGTH_SHORT).show();\n mStudentGradeEditText.requestFocus();\n return false;\n } else {\n int studentGrade = Integer.parseInt(studentGradeString);\n if (studentGrade <= 0) {\n Toast.makeText(this, R.string.please_enter_valid_grade, Toast.LENGTH_SHORT).show();\n mStudentGradeEditText.requestFocus();\n return false;\n }\n }\n\n return true;\n }", "private boolean validCreateInput() throws SQLException {\n // Checks if any of the fields is empty\n if(teamNameCreateField.getText().equals(\"\") || abbrevationCreateField.getText().equals(\"\")\n || chooseCityBoxCreate.getValue() == null || chooseLeagueBoxCreate.getValue() == null\n || chooseAgeGroupCreate.getValue() == null || chooseLeagueTeamBoxCreate.getValue() == null){\n displayMessage(messagePane,\"Please fill all the fields\",true);\n return false;\n }\n // Checks the abbrevation length\n else if(abbrevationCreateField.getText().length() > 3)\n {\n displayMessage(messagePane,\"Abbrevations must be at most 3 characters\",true);\n return false;\n }\n // Checks team name length\n else if (teamNameCreateField.getText().length() > 30){\n displayMessage(messagePane,\"Team Names must be smaller than 30 characters\",true);\n return false;\n }\n return true;\n }", "private boolean isInputValid() {\n return true;\n }", "private boolean checkFields() {\n boolean test = true;\n if (fname.isEmpty()) {\n test = false;\n }\n if (lname.isEmpty()) {\n test = false;\n }\n if (cin.isEmpty()) {\n test = false;\n }\n if (typeCompte.equals(\"Bancaire\")) {\n if (decouvertNF.isEmpty())\n test = false;\n } else if (typeCompte.equals(\"Epargne\")) {\n if (tauxInteretNF.isEmpty())\n test = false;\n }\n if (s_datePK.getValue() == null) {\n s_datePK.setStyle(\"-fx-border-color:red;-fx-border-radius:3px;-fx-border-size: 1px;\");\n test = false;\n }\n\n return test;\n }", "protected boolean validateInputs() {\n if (KEY_EMPTY.equals(firstName)) {\n etFirstName.setError(\"First Name cannot be empty\");\n etFirstName.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(lastName)) {\n etLastName.setError(\"Last Name cannot be empty\");\n etLastName.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(username)) {\n etUsername.setError(\"Username cannot be empty\");\n etUsername.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(email)) {\n etEmail.setError(\"Email cannot be empty\");\n etEmail.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(password)) {\n etPassword.setError(\"Password cannot be empty\");\n etPassword.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(confirmPassword)) {\n etConfirmPassword.setError(\"Confirm Password cannot be empty\");\n etConfirmPassword.requestFocus();\n return false;\n }\n if (!password.equals(confirmPassword)) {\n etConfirmPassword.setError(\"Password and Confirm Password does not match\");\n etConfirmPassword.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(major)) {\n etMajor.setError(\"Major cannot be empty\");\n etMajor.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(university)) {\n etUniversity.setError(\"university cannot be empty\");\n etUniversity.requestFocus();\n return false;\n }\n\n\n\n if(!isStudent && !isTutor){\n //Show a toast or some kind of error\n Toast toast = Toast.makeText(this, \"message\", Toast.LENGTH_SHORT);\n toast.setText(\"please check the account type\");\n toast.setGravity(Gravity.CENTER, 0, 0);\n //other setters\n toast.show();\n return false;\n }\n\n\n return true;\n }", "private boolean validInput()\n {\n boolean completeForm = true; //all textfields have been filled in\n boolean noExceptions = true; //all textfields (except name) have int\n boolean selectionMade = true; //user has selected a ship type\n\n if (shipNameInput.getText()==\"Ship name\" ||\n xcoordInput.getText()==\"Starting x coordinate\" ||\n ycoordInput.getText()==\"Starting y coordinate\")\n {\n System.out.println(\"ERROR: Please fill in all text fields before \"+\n \"adding your ship.\");\n completeForm = false;\n }\n try\n {\n xcoord = Integer.parseInt(xcoordInput.getText());\n ycoord = Integer.parseInt(ycoordInput.getText());\n }\n catch (NumberFormatException except)\n {\n System.out.println(\"ERROR: Ship coordinates and speed need to be \"+\n \"entered as integers.\");\n noExceptions = false;\n }\n if (directionInput.getResponse() == \"none\")\n {\n System.out.println(\"ERROR: Please choose a direction.\");\n selectionMade = false;\n }\n else\n {\n String d = directionInput.getResponse();\n if (d == \"N\") direction = 0;\n else if (d == \"NE\") direction = Ship.NE;\n else if (d == \"E\") direction = Ship.E;\n else if (d == \"SE\") direction = Ship.SE;\n else if (d == \"S\") direction = Ship.S;\n else if (d == \"SW\") direction = Ship.SW;\n else if (d == \"W\") direction = Ship.W;\n else if (d == \"NW\") direction = Ship.NW;\n }\n shipName = shipNameInput.getText();\n speed = speedSlider.getValue();\n\n return (completeForm && noExceptions && selectionMade);\n }", "private boolean validate() {\n if (category.equals(\"n/a\")) {\n AppUtils.displayToast(mContext, \"Please select category!!!\");\n return false;\n } else if (category.equals(AppUtils.CREATE_CATEGORY) && mCustomCategory.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter custom category name!!!\");\n return false;\n } else if (mTaskTile.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter task Title!!!\");\n return false;\n } else if (dueDate == 0) {\n AppUtils.displayToast(mContext, \"Please enter due date!!\");\n return false;\n } else if (mTaskContent.getText().toString().length() == 0) {\n AppUtils.displayToast(mContext, \"Please enter task content!!!\");\n return false;\n } else\n return true;\n\n\n }", "public boolean isInputValid()\n {\n String[] values = getFieldValues();\n if(values[0].length() > 0 || values[1].length() > 0 || values[2].length() > 0)\n return true;\n else\n return false;\n }", "private boolean validateInputInfo(){\n\n //Get user input\n String firstName = newContactFirstName.getText().toString();\n String lastName = newContactLastName.getText().toString();\n String email = newContactEmailAddress.getText().toString();\n String phone = newContactPhoneNumber.getText().toString();\n\n //Check to make sure no boxes were left empty\n if(firstName.isEmpty() || lastName.isEmpty() || email.isEmpty() || phone.isEmpty()){\n Toast.makeText(this, \"You must fill all fields before continuing!\", Toast.LENGTH_LONG).show();\n return false;\n }\n //Check to see if phone number is valid\n else if(!(phone.length() >= 10)){\n Toast.makeText(this, \"Make sure to input a valid 10 digit phone number!\", Toast.LENGTH_LONG).show();\n return false;\n }\n\n return true;\n }", "private boolean isInputValid() {\n String errorMessage = \"\";\n\n if (ServiceName.getText() == null || ServiceName.getText().length() == 0) {\n errorMessage += \"No valid name!\\n\";\n }\n if (Serviceemail.getText() == null || Serviceemail.getText().length() == 0) {\n Pattern p = Pattern.compile(\"[_A-Za-z0-9][A-Za-z0-9._]*?@[_A-Za-z0-9]+([.][_A-Za-z]+)+\");\n Matcher m = p.matcher(Serviceemail.getText());\n if (m.find() && m.group().equals(Serviceemail.getText())) {\n errorMessage += \"No valid Mail Forment!\\n\";\n }\n }\n if (servicedescrip.getText() == null || servicedescrip.getText().length() == 0) {\n errorMessage += \"No valid description !\\n\";\n }\n if (f == null && s.getImage() == null) {\n errorMessage += \"No valid photo ( please upload a photo !)\\n\";\n }\n if (Serviceprice.getText() == null || Serviceprice.getText().length() == 0) {\n errorMessage += \"No valid prix !\\n\";\n } else {\n // try to parse the postal code into an int.\n try {\n Float.parseFloat(Serviceprice.getText());\n } catch (NumberFormatException e) {\n errorMessage += \"No valid prix (must be a Float)!\\n\";\n }\n }\n if ( !Weekly.isSelected() && !Daily.isSelected() && !Monthly.isSelected()) {\n errorMessage += \"No valid Etat ( select an item !)\\n\";\n }\n if (Servicesatet.getSelectionModel().getSelectedIndex() == -1) {\n errorMessage += \"No valid etat ( select an item !)\\n\";\n }\n if (ServiceCity.getSelectionModel().getSelectedIndex() == -1) {\n errorMessage += \"No valid City ( select an item !)\\n\";\n }\n if (servicetype.getSelectionModel().getSelectedIndex() == -1) {\n errorMessage += \"No valid Type ( select an item !)\\n\";\n }\n if (errorMessage.length() == 0) {\n return true;\n } else {\n // Show the error message.\n Alert alert = new Alert(Alert.AlertType.ERROR);\n alert.setTitle(\"Invalid Fields\");\n alert.setHeaderText(\"Please correct invalid fields\");\n alert.setContentText(errorMessage);\n alert.showAndWait();\n return false;\n }\n }", "protected abstract boolean isInputValid();", "public Boolean validEntries() {\n String orderNumber = orderNo.getText();\n String planTime = plannedTime.getText();\n String realTime = actualTime.getText();\n String worker = workerSelected();\n String productType = productTypeSelected();\n Boolean validData = false;\n if (orderNumber.equals(\"\")) {\n warning.setText(emptyOrderNum);\n } else if (!Validation.isValidOrderNumber(orderNumber)) {\n warning.setText(invalidOrderNum);\n } else if (worker.equals(\"\")) {\n warning.setText(workerNotSelected);\n } else if (productType.equals(\"\")) {\n warning.setText(productTypeNotSelected);\n } else if (planTime.equals(\"\")) {\n warning.setText(emptyPlannedTime);\n } else if (!Validation.isValidPlannedTime(planTime)) {\n warning.setText(invalidPlannedTime);\n } else if (!actualTime.getText().isEmpty() && !Validation.isValidActualTime(realTime)) {\n warning.setText(invalidActualTime);\n } else if (comboStatus.getSelectionModel().isEmpty()) {\n warning.setText(emptyStatus);\n } else validData = true;\n return validData;\n }", "private boolean validateInput(){\n boolean operationOK = true;\n //perform input validation on the double values in the form\n String integrationTime = this.integrationTimeText.getText();\n String integrationFrequency = this.integrationFrequencyText.getText();\n \n if(!integrationTime.equals(\"\")){\n try {\n Double itime = Double.parseDouble(integrationTime);\n integrationTimeText.setBackground(Color.WHITE);\n integrationTimeText.setToolTipText(\"Time in seconds (s)\");\n } catch (NumberFormatException ex) {\n integrationTimeText.setBackground(Color.RED);\n operationOK=false;\n integrationTimeText.setToolTipText(\"This field has to be a valid double (eg. 1.5)\");\n }\n }\n if(!integrationFrequency.equals(\"\")){\n try {\n Double itime = Double.parseDouble(integrationFrequency);\n integrationFrequencyText.setBackground(Color.WHITE);\n integrationFrequencyText.setToolTipText(\"Frequency in Hertz (Hz)\");\n \n } catch (NumberFormatException ex) {\n operationOK=false;\n integrationFrequencyText.setBackground(Color.RED);\n integrationFrequencyText.setToolTipText(\"This field has to be a valid double (eg. 1.5)\");\n }\n }\n if(currentStepOperationsPanel!=null){\n operationOK = this.currentStepOperationsPanel.validateInput();\n \n }\n return operationOK;\n }", "boolean validateInput() {\n if (etFullname.getText().toString().equals(\"\")) {\n etFullname.setError(\"Please Enter Full Name\");\n return false;\n }\n if (etId.getText().toString().equals(\"\")) {\n etId.setError(\"Please Enter ID\");\n return false;\n }\n if (etEmail.getText().toString().equals(\"\")) {\n etEmail.setError(\"Please Enter Email\");\n return false;\n }\n if (etHall.getText().toString().equals(\"\")) {\n etHall.setError(\"Please Enter Hall Name\");\n return false;\n }\n if (etAge.getText().toString().equals(\"\")) {\n etAge.setError(\"Please Enter Age\");\n return false;\n }\n if (etPhone.getText().toString().equals(\"\")) {\n etPhone.setError(\"Please Enter Contact Number\");\n return false;\n }\n if (etPassword.getText().toString().equals(\"\")) {\n etPassword.setError(\"Please Enter Password\");\n return false;\n }\n\n // checking the proper email format\n if (!isEmailValid(etEmail.getText().toString())) {\n etEmail.setError(\"Please Enter Valid Email\");\n return false;\n }\n\n // checking minimum password Length\n if (etPassword.getText().length() < MIN_PASSWORD_LENGTH) {\n etPassword.setError(\"Password Length must be more than \" + MIN_PASSWORD_LENGTH + \"characters\");\n return false;\n }\n\n\n return true;\n }", "private boolean validateInputs() {\n if (KEY_EMPTY.equals(tenchuxe)) {\n etTenChuXe.setError(\"Vui lòng điền Tên chủ xe\");\n etTenChuXe.requestFocus();\n return false;\n\n }\n if (KEY_EMPTY.equals(sdt)) {\n etSDT.setError(\"Vui lòng điền Số điện thoại\");\n etSDT.requestFocus();\n return false;\n\n }\n if (KEY_EMPTY.equals(mota)) {\n edMoTa.setError(\"Vui lòng điền Mô tả xe\");\n edMoTa.requestFocus();\n return false;\n\n }\n if (KEY_EMPTY.equals(biensoxe)) {\n etBienSoXe.setError(\"Vui lòng điền Biển số xe\");\n etBienSoXe.requestFocus();\n return false;\n }\n if (KEY_EMPTY.equals(passwordtx)) {\n etPasswordtx.setError(\"Vui lòng điền Mật khẩu\");\n etPasswordtx.requestFocus();\n return false;\n }\n\n if (KEY_EMPTY.equals(confirmPassword)) {\n etConfirmPassword.setError(\"Vui lòng điền Xác nhận mật khẩu\");\n etConfirmPassword.requestFocus();\n return false;\n }\n if (!passwordtx.equals(confirmPassword)) {\n etConfirmPassword.setError(\"Xác nhận mật khẩu sai !\");\n etConfirmPassword.requestFocus();\n return false;\n }\n\n return true;\n }", "private boolean validEditInput() throws SQLException {\n // Checks if any of the fields is empty\n if(teamNameEditField.getText().equals(\"\") || abbrevationEditField.getText().equals(\"\")\n || chooseCityBox.getValue() == null || chooseLeagueBox.getValue() == null\n || chooseLeagueTeamBox.getValue() == null) {\n displayMessage(messagePane,\"Please fill all the fields\",true);\n return false;\n }\n // Checks the abbrevation length\n else if(abbrevationEditField.getText().length() > 3)\n {\n displayMessage(messagePane,\"Abbrevations must be at most 3 characters\",true);\n return false;\n }\n // Checks team name length\n else if (teamNameEditField.getText().length() > 30){\n displayMessage(messagePane,\"Team Names must be smaller than 30 characters\",true);\n return false;\n }\n return true;\n }", "private boolean validateInputs(){\n if(jrTakeTest.isSelected()==false && jrViewScores.isSelected()==false && jrChangePassword.isSelected()==false)\n return false;\n return true;\n}", "private boolean isValidInput() {\n\t\treturn true;\n\t}", "private boolean isInputValid() {\n boolean isValidInput = true;\n\n if (TextUtils.isEmpty(studentID)) {\n Validator.setEmptyError(studentIDLayout);\n isValidInput = false;\n } else {\n studentIDLayout.setError(null);\n studentIDLayout.setErrorEnabled(false);\n }\n\n if (TextUtils.isEmpty(studentName)) {\n Validator.setEmptyError(studentNameLayout);\n isValidInput = false;\n } else {\n studentNameLayout.setError(null);\n studentNameLayout.setErrorEnabled(false);\n }\n\n if (TextUtils.isEmpty(fatherName)) {\n Validator.setEmptyError(fatherNameLayout);\n isValidInput = false;\n } else {\n fatherNameLayout.setError(null);\n fatherNameLayout.setErrorEnabled(false);\n }\n\n if (TextUtils.isEmpty(gender)) {\n genderErrorText.setVisibility(View.VISIBLE);\n isValidInput = false;\n } else {\n genderErrorText.setVisibility(View.GONE);\n }\n\n if (TextUtils.isEmpty(phone)) {\n Validator.setEmptyError(phoneLayout);\n isValidInput = false;\n } else if (!Validator.isValidMobile(phone)) {\n isValidInput = false;\n phoneLayout.setError(\"This phone is not valid\");\n } else {\n phoneLayout.setError(null);\n phoneLayout.setErrorEnabled(false);\n }\n\n if (TextUtils.isEmpty(email)) {\n Validator.setEmptyError(emailLayout);\n isValidInput = false;\n } else if (!Validator.isValidEmail(email)) {\n isValidInput = false;\n emailLayout.setError(\"This email is not valid\");\n } else {\n emailLayout.setError(null);\n emailLayout.setErrorEnabled(false);\n }\n\n return isValidInput;\n }", "public boolean verifyData()\n {\n if(jTextFieldName.getText().equals(\"\") && jTextFieldNumber.getText().equals(\"\") \n || jTextFieldSupplier.getText().equals(\"\") || jTextArea1.getText().equals(\"\") || jTextFieldModel.getText().equals(\"\"))\n {\n JOptionPane.showMessageDialog(null, \"One or More Fields Are Empty\");\n return false;\n }\n \n else\n {\n return true;\n }\n \n }", "private boolean checkFields() {\n if (editTxtName.getText().equals(\"\")) return false;//name\n if (editTxtDesc.getText().equals(\"\")) return false;//desc\n if (editClrColor.getValue() == null) return false;//color\n if (oldEnvironment == null) return false;//environment is null\n return true;//everything is valid\n }", "private boolean checkInfo()\n {\n boolean flag = true;\n if(gName.isEmpty())\n {\n groupName.setError(\"Invalid name\");\n flag = false;\n }\n if(gId.isEmpty())\n {\n groupId.setError(\"Invalid id\");\n flag = false;\n }\n if(gAddress.isEmpty())\n {\n groupAddress.setError(\"Invalid address\");\n flag = false;\n }\n\n for(char c : gName.toCharArray()){\n if(Character.isDigit(c)){\n groupName.setError(\"Invalid Name\");\n flag = false;\n groupName.requestFocus();\n }\n }\n\n if(groupType.isEmpty())\n {\n flag = false;\n rPublic.setError(\"Choose one option\");\n }\n\n if(time.isEmpty())\n time = \"not set\";\n\n if(groupDescription.getText().toString().length()<20||groupDescription.getText().toString().length()>200)\n groupDescription.setError(\"Invalid description\");\n\n return flag;\n }", "private boolean validate() {\n if(edtMobileNumber.getText().toString().length() <= 0){\n edtMobileNumber.setFocusable(true);\n edtMobileNumber.setError(Constants.ERR_MSG_MOBILE);\n return false;\n }else if(edtFirstName.getText().toString().length() <= 0){\n edtFirstName.setFocusable(true);\n edtFirstName.setError(Constants.ERR_MSG_FIRST_NAME);\n return false;\n }else if(edtLastName.getText().toString().length() <= 0){\n edtLastName.setFocusable(true);\n edtLastName.setError(Constants.ERR_MSG_LAST_NAME);\n return false;\n }else if(edtDateOfBirth.getText().toString().length() <= 0){\n edtDateOfBirth.setFocusable(true);\n edtDateOfBirth.setError(Constants.ERR_MSG_DATE_OF_BIRTH);\n return false;\n }else if(edtEnterPin.getText().toString().length() <= 0){\n edtEnterPin.setFocusable(true);\n edtEnterPin.setError(Constants.ERR_MSG_PIN);\n return false;\n }else if(edtConfirmPin.getText().toString().length() <= 0){\n edtConfirmPin.setFocusable(true);\n edtConfirmPin.setError(Constants.ERR_MSG_CONFIRM_PIN);\n return false;\n }else if(spnStatus.getSelectedItemPosition() == 0){\n Toast.makeText(context, Constants.ERR_MSG_STATUS, Toast.LENGTH_SHORT).show();\n return false;\n }else if(spnBloodGroup.getSelectedItemPosition() == 0){\n Toast.makeText(context, Constants.ERR_MSG_BLOOD_GROUP, Toast.LENGTH_SHORT).show();\n return false;\n }else if(rgGender.getCheckedRadioButtonId() == -1){\n Toast.makeText(context,Constants.ERR_MSG_GENDER,Toast.LENGTH_SHORT).show();\n return false;\n }\n return true;\n }", "public boolean validateInput(boolean showMessage) {\n\n boolean valid = true;\n\n valid = GuiUtilities.validateIntegerInput(this, peptideLengthLabel, minPepLengthTxt, \"minimum peptide length\", \"Peptide Length Error\", true, showMessage, valid);\n valid = GuiUtilities.validateIntegerInput(this, peptideLengthLabel, maxPepLengthTxt, \"minimum peptide length\", \"Peptide Length Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, precursorMassLabel, minPrecursorMassTxt, \"minimum precursor mass\", \"Precursor Mass Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, precursorMassLabel, maxPrecursorMassTxt, \"maximum precursor mass\", \"Precursor Mass Error\", true, showMessage, valid);\n\n if (!minPtmsPerPeptideTxt.getText().trim().isEmpty()) {\n valid = GuiUtilities.validateIntegerInput(this, variablePtmsPerPeptideLabel, minPtmsPerPeptideTxt, \"minimum number of variable PTMs\", \"Variable PTMs Error\", true, showMessage, valid);\n }\n \n if (!maxPtmsPerPeptideTxt.getText().trim().isEmpty()) {\n valid = GuiUtilities.validateIntegerInput(this, variablePtmsPerPeptideLabel, maxPtmsPerPeptideTxt, \"maximum number of variable PTMs\", \"Variable PTMs Error\", true, showMessage, valid);\n }\n\n valid = GuiUtilities.validateIntegerInput(this, maxVariablePtmsPerTypeLabel, maxVariablePtmsPerTypeTxt, \"maximum number of variable PTMs per type\", \"Variable PTMs Error\", true, showMessage, valid);\n valid = GuiUtilities.validateIntegerInput(this, decoySeedLabel, decoySeedTxt, \"decoy seed\", \"Decoy Seed Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, spectrumMzLabel, minSpectrumMzTxt, \"minimum spectrum mz\", \"Spectrum Mz Error\", true, showMessage, valid);\n if (!maxSpectrumMzTxt.getText().trim().isEmpty()) {\n valid = GuiUtilities.validateDoubleInput(this, spectrumMzLabel, maxSpectrumMzTxt, \"maximum spectrum mz\", \"Spectrum Mz Error\", true, showMessage, valid);\n }\n valid = GuiUtilities.validateIntegerInput(this, minPeaksLbl, minPeaksTxt, \"minimum number of peaks\", \"Spectrum Peaks Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, removePrecursorPeakLabel, removePrecursorPeakToleranceTxt, \"remove precursor peak tolerance\", \"Precursor Peak Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, mzBinWidthLabel, mzBinWidthTxt, \"mz bin width\", \"Mz Bin Width Error\", true, showMessage, valid);\n valid = GuiUtilities.validateDoubleInput(this, mzBinOffsetLabel, mzBinOffsetTxt, \"mz bin offset\", \"Mz Bin Offset Error\", true, showMessage, valid);\n valid = GuiUtilities.validateIntegerInput(this, numberMatchesLabel, numberMatchesTxt, \"number of spectrum matches\", \"Number of Spectrum Matches Error\", true, showMessage, valid);\n\n // peptide length: the low value should be lower than the high value\n try {\n double lowValue = Double.parseDouble(minPepLengthTxt.getText().trim());\n double highValue = Double.parseDouble(maxPepLengthTxt.getText().trim());\n\n if (lowValue > highValue) {\n if (showMessage && valid) {\n JOptionPane.showMessageDialog(this, \"The lower range value has to be smaller than the upper range value.\",\n \"Peptide Length Error\", JOptionPane.WARNING_MESSAGE);\n }\n valid = false;\n peptideLengthLabel.setForeground(Color.RED);\n peptideLengthLabel.setToolTipText(\"Please select a valid range (upper <= higher)\");\n }\n } catch (NumberFormatException e) {\n // ignore, handled above\n }\n\n // precursor mass range: the low value should be lower than the high value\n try {\n double lowValue = Double.parseDouble(minPrecursorMassTxt.getText().trim());\n double highValue = Double.parseDouble(maxPrecursorMassTxt.getText().trim());\n\n if (lowValue > highValue) {\n if (showMessage && valid) {\n JOptionPane.showMessageDialog(this, \"The lower range value has to be smaller than the upper range value.\",\n \"Precursor Mass Range Error\", JOptionPane.WARNING_MESSAGE);\n }\n valid = false;\n precursorMassLabel.setForeground(Color.RED);\n precursorMassLabel.setToolTipText(\"Please select a valid range (upper <= higher)\");\n }\n } catch (NumberFormatException e) {\n // ignore, handled above\n }\n\n // spectrum mz range: the low value should be lower than the high value\n try {\n double lowValue = Double.parseDouble(minSpectrumMzTxt.getText().trim());\n double highValue = Double.parseDouble(maxSpectrumMzTxt.getText().trim());\n\n if (lowValue > highValue) {\n if (showMessage && valid) {\n JOptionPane.showMessageDialog(this, \"The lower range value has to be smaller than the upper range value.\",\n \"Spectrum Mz Range Error\", JOptionPane.WARNING_MESSAGE);\n }\n valid = false;\n spectrumMzLabel.setForeground(Color.RED);\n spectrumMzLabel.setToolTipText(\"Please select a valid range (upper <= higher)\");\n }\n } catch (NumberFormatException e) {\n // ignore, handled above\n }\n\n okButton.setEnabled(valid);\n return valid;\n }", "private boolean checkValidity() {\n if(txtSupplierCode.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(null, \"Please Enter the Supplier Code!!\", \"EMPTY SUPPLIER CODE\", JOptionPane.ERROR_MESSAGE);\n txtSupplierCode.setBackground(Color.RED);\n return false;\n }\n if(txtSupplierName.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(null, \"Please Enter the Supplier Name!!\", \"EMPTY SUPPLIER NAME\", JOptionPane.ERROR_MESSAGE);\n txtSupplierName.setBackground(Color.RED);\n return false;\n }\n return true;\n }", "private boolean validateInput(){\n boolean result = false;\n\n if(!us.setUsername(userField.getText())){\n errorLabel.setText(\"Nombre de usuario invalido\");\n } else if(!us.setPassword(passField.getText())){ //Valido 1 por uno los campos que ingreso el usuario\n errorLabel.setText(\"Contraseña invalida\");\n } else if(!us.setName(nameField.getText())){\n errorLabel.setText(\"Nombre Invalido\");\n } else if(!us.setSurname(surnameField.getText())){\n errorLabel.setText(\"Apellido Invalido\");\n } else if(!us.setDni(dniField.getText())){\n errorLabel.setText(\"Dni invalido\");\n } else if(!ageField.getText().matches(\"\\\\d{2}\")){\n errorLabel.setText(\"Edad invalida\");\n }\n else{\n us.setAge(Integer.parseInt(ageField.getText()));\n result = true;\n }\n return result;\n }", "public boolean checkValidity() {\n String sep = DECIMAL_FORMAT.getDecimalFormatSymbols().getDecimalSeparator() + \"\";\n String name = nameField.getText().trim();\n String priceText = valueField.getText().trim();\n if (name.equals(\"\") || priceText.equals(\"\")) {\n Utils.showWarningMessage(getRootPane(), \"The fields can not be empty!\");\n return false;\n }\n String price = priceText.replace(sep, \"\");\n if (!price.matches(\"^[0-9]+$\")) {\n Utils.showWarningMessage(getRootPane(), \"Please enter a valid price!\");\n return false;\n }\n int priceInt = Integer.parseInt(price);\n if (priceInt == 0) {\n Utils.showWarningMessage(getRootPane(), \"The price can not be 0.\");\n return false;\n }\n return true;\n }", "private boolean validateRequiredFields(StringBuffer b){\n boolean result = true;\n\n if (!TextFieldHelper.isNumericFieldValid(this.goalValue, \" Цель: \", b) ||\n !TextFieldHelper.isNumericFieldValid(this.startWeightValue, \" Исходный вес: \", b) ||\n !TextFieldHelper.isNumericFieldValid(this.heightValue, \" Рост: \", b) ||\n !CalendarHelper.isFieldValid(startProgramDateValue, \" Старт программы: \", b) ||\n !new ComboBoxFieldHelper<Client>().isFieldValid(clientFIOValue, \" Клиент: \", b))\n {\n result = false;\n }\n\n return result;\n }", "private boolean checkValidations() {\n double originalPrice = 0.0, newPrice = 0.0;\n try {\n originalPrice = Double.parseDouble(etOriginalPrice.getText().toString());\n newPrice = Double.parseDouble(tvNewPrice.getText().toString());\n } catch (NumberFormatException ne) {\n ne.printStackTrace();\n }\n if (TextUtils.isEmpty(etTitle.getText().toString().trim())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_title_war));\n return false;\n } else if (TextUtils.isEmpty(etDescription.getText().toString().trim())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_description_war));\n return false;\n } else if (TextUtils.isEmpty(etTotalItems.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_total_items));\n return false;\n } else if (Integer.parseInt(etTotalItems.getText().toString()) < 1) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_total_items));\n return false;\n } else if (TextUtils.isEmpty(etOriginalPrice.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_original_price));\n return false;\n } else if (Double.parseDouble(etOriginalPrice.getText().toString().trim()) < 1) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.zero_original_price));\n return false;\n } else if (TextUtils.isEmpty(tvNewPrice.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_new_price));\n return false;\n } else if (originalPrice < newPrice) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.new_price_cant_greater));\n return false;\n } else if (TextUtils.isEmpty(etBeginTime.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_begin_time));\n return false;\n } else if (TextUtils.isEmpty(etEndTime.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.empty_end_time));\n return false;\n } else if (appUtils.isBeforeCurrentTime(etBeginTime.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.start_time_cant_be_less));\n return false;\n } else if (!checktimings(etBeginTime.getText().toString(), etEndTime.getText().toString())) {\n appUtils.showSnackBar(mActivity.findViewById(android.R.id.content), getString(R.string.end_time_cant_less));\n return false;\n } else\n return true;\n }", "private void verifyInput(){\n String firstName = mFirstNameField.getText().toString();\n String lastName = mLastNameField.getText().toString();\n\n mNameFieldsFilled = !TextUtils.isEmpty(firstName) && !TextUtils.isEmpty(lastName);\n\n }", "private boolean isInputValid() {\n String errorMessage = \"\";\n\n if (commentField.getText() == null || commentField.getText().length() == 0) {\n errorMessage += \"Не введен комментарий!\\n\";\n }\n if (timeField.getText() == null || timeField.getText().length() == 0) {\n errorMessage += \"Не введено время выполнения задачи!\\n\";\n }\n if (errorMessage.length() == 0) {\n return true;\n } if (errorMessage.length() == 0) {\n return true;\n } else {\n // Show the error message.\n Alert alert = new Alert(Alert.AlertType.INFORMATION);\n alert.setTitle(\"Не введены все данные!\");\n alert.setHeaderText(null);\n alert.setContentText(\"Пожалуйста, введите все данные!\");\n alert.showAndWait();\n return false;\n }\n }", "public boolean isDataValid() {\r\n boolean dataValid = true;\r\n\r\n if (this.needDefaultValue) {\r\n try {\r\n this.getDefaultValue();\r\n } catch (Exception e) {\r\n dataValid = false;\r\n }\r\n }\r\n\r\n if (this.nameTextField.getText() == null || this.nameTextField.getText().length() == 0) {\r\n dataValid = false;\r\n }\r\n\r\n return dataValid;\r\n\r\n }", "private boolean isInputValid() {\n\t\tString errorMessage = \"\";\n\t\t\n\t\tif (dateField.getText() == null || dateField.getText().length() == 0) {\n\t\t\terrorMessage += \"Kein gültiges Datum!\\n\";\n\t\t} else {\n\t\t\tif (!DateUtil.validDate(dateField.getText())) {\n\t\t\t\terrorMessage += \"Kein gültiges Datum. Benutze das dd.mm.yyy Format!\\n\";\n\t\t\t}\n\t\t}\n\t\tString categoryFieldSelection = categoryField.getSelectionModel().getSelectedItem();\n\t\tif (categoryFieldSelection.isEmpty() || categoryFieldSelection.length() == 0) {\n\t\t\terrorMessage += \"Keine gültige Kategorie!\\n\";\n\t\t}\n\t\tif (useField.getText() == null || useField.getText().length() == 0) {\n\t\t\terrorMessage += \"Kein gültiger Verwendungszweck!\\n\";\n\t\t}\n\t\tif (amountField.getText() == null || amountField.getText().length() == 0) {\n\t\t\terrorMessage += \"Kein gültiger Betrag!\\n\";\n\t\t} \n\t\t/**else {\n\t\t\t// try to parse the amount into a double\n\t\t\ttry {\n\t\t\t\tDouble.parseDouble(amountField.getText());\n\t\t\t} catch (NumberFormatException e) {\n\t\t\t\terrorMessage += \"Kein zulässiger Betrag! (Nur Dezimalzahlen erlaubt)\\n\";\n\t\t\t}\n\t\t}**/\n\t\tif (distributionKindField.getText() == null || distributionKindField.getText().length() == 0) {\n\t\t\terrorMessage += \"Keine gültige Ausgabeart!\\n\";\n\t\t}\n\n\t\tif (errorMessage.length() == 0) {\n\t\t\treturn true;\n\t\t} else {\n\t\t\t// Show the error message.\n\t\t\tAlert alert = new Alert(AlertType.ERROR);\n\t\t\talert.initOwner(dialogStage);\n\t\t\talert.setTitle(\"Ungültige Eingaben\");\n\t\t\talert.setHeaderText(\"Bitte korrigieren Sie die Fehler in den Feldern.\");\n\t\t\talert.setContentText(errorMessage);\n\t\t\talert.showAndWait();\n\t\t\treturn false;\n\t\t}\n\t}", "private boolean checkValidations() {\n if (TextUtils.isEmpty(etFirstName.getText().toString().trim())) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.empty_name_war));\n return false;\n } else if (etPhoneNo.getText().length() > 0 && etPhoneNo.getText().toString().trim().length() < 7) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.valid_mo_no_war));\n return false;\n }\n /*else if (TextUtils.isEmpty(etAdress.getText().toString().trim())) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.empty_address_war));\n return false;\n } else if (countryId==null || countryId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.country_war));\n return false;\n } else if (stateId==null || stateId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.state_war));\n return false;\n }*/ /*else if (cityId==null || cityId.equals(\"\")) {\n appUtils.showSnackBar(getActivity().findViewById(android.R.id.content), getString(R.string.city_war));\n return false;\n }*/\n else\n return true;\n }", "private boolean isInputValid() {\r\n String errorMessage = \"\";\r\n\r\n if (errorMessage.length() == 0) {\r\n return true;\r\n } else {\r\n// Show the error message.\r\n Dialogs.create()\r\n .title(\"Invalid Fields\")\r\n .masthead(\"Please correct invalid fields\")\r\n .message(errorMessage)\r\n .showError();\r\n return false;\r\n }\r\n }", "private boolean CheckAllRequiredFields() {\n\t\tboolean res = true;\n\t\tres &= CheckParkSelection();\n\t\tres &= CheckDateSelection();\n\t\tres &= CheckVisitorHour();\n\t\tres &= CheckEmail();\n\t\tres &= CheckPhoneNumber();\n\t\treturn res;\n\t}", "private boolean formIsValid(){\r\n // check if all the required fields have been filled in\r\n boolean allFieldsEntered = formComplete();\r\n // check if Name field has valid input\r\n boolean nameFieldValid = isAllChars(NAME_FIELD.getText());\r\n // check if city field has valid input\r\n boolean cityFieldValid = isAllChars(CITY_FIELD.getText());\r\n // check if country field has valid input\r\n boolean ctryFieldValid = isAllChars(COUNTRY_FIELD.getText());\r\n // check if zipcode field has valid input\r\n boolean zipFieldValid = isAllNums(ZIP_FIELD.getText());\r\n // check if phone field has valid input\r\n boolean phoneFieldValid = isAllNums(PHONE_FIELD.getText());\r\n // check if all fields and form are valid\r\n return allFieldsEntered && nameFieldValid &&\r\n cityFieldValid && ctryFieldValid &&\r\n zipFieldValid && phoneFieldValid; \r\n }", "public boolean Validate() {\n String[] testArr = {titleTxf.getText(), fNameTxf.getText(), sNameTxf.getText(),\n initialTxf.getText(), hNumTxf.getText(), cNumTxf.getText(), emailTxf.getText(), idNumTxf.getText(),\n (String) maritalCbx.getSelectedItem(), \n resTxf1.getText() + \"\" + resTxf2.getText(), zipResTxf.getText(),postTxf1.getText() + \"\" + postTxf2.getText(),\n zipPostTxf.getText() };\n\n // verify user has entered data into required fields\n String inputTest = \"\";\n\n for (int i = 0; i < testArr.length; i++) {\n if (testArr[i].equals(inputTest)) {\n\n JOptionPane.showMessageDialog(rootPane, \"please fill in all required fields\", \"ERROR\", ERROR_MESSAGE);\n \n return false;\n \n\n }\n \n \n }\n //verify Home number\n if(hNumTxf.getText().length()!=10){\n \n JOptionPane.showMessageDialog(rootPane, \"Invaild Home number\", \"ERROR\", ERROR_MESSAGE);\n errHNum.setText(\"!\");\n \n return false;\n }\n else{\n errHNum.setText(\"\");\n }\n //verify CellNo\n if(cNumTxf.getText().length()!=10){\n \n JOptionPane.showMessageDialog(rootPane, \"Invaild Cellphone number\", \"ERROR\", ERROR_MESSAGE);\n errCNum.setText(\"!\");\n \n return false;\n \n }\n else{\n errCNum.setText(\"\");\n }\n //verify email\n String email =emailTxf.getText(); \n if(!email.contains(\"@\")|| !email.contains(\".\")){\n \n JOptionPane.showMessageDialog(rootPane, \"Invaild email address\", \"ERROR\", ERROR_MESSAGE);\n errEmail.setText(\"!\");\n return false;\n }\n else{\n errEmail.setText(\"\");\n }\n \n //verify ID No. (Local)\n String ID = idNumTxf.getText();\n if(ID.length()!=13){\n \n JOptionPane.showMessageDialog(rootPane, \"Invaild ID number\", \"ERROR\", ERROR_MESSAGE);\n errID.setText(\"!\");\n return false;\n }\n else{\n errID.setText(\"\");\n }\n \n if(zipResTxf.getText().length()!=4){\n JOptionPane.showMessageDialog(rootPane, \"Invaild Zip Code\", \"ERROR\", ERROR_MESSAGE);\n errZipRes.setText(\"!\");\n return false;\n \n }\n else{\n \n errZipRes.setText(\"\");\n }\n if(zipPostTxf.getText().length()!=4){\n JOptionPane.showMessageDialog(rootPane, \"Invaild Zip Code\", \"ERROR\", ERROR_MESSAGE);\n errZipPost.setText(\"!\");\n return false;\n \n }\n else{\n \n errZipPost.setText(\"\");\n }\n \n \n return true;\n\n }", "private boolean isValidate() {\n name = edt_name.getText().toString();\n phone = edt_phone.getText().toString();\n landMark = edt_landmark.getText().toString();\n address = edt_address.getText().toString();\n city = edt_city.getText().toString();\n state = edt_state.getText().toString();\n if (name.length() == 0) {\n edt_name.setError(\"Please Enter Name \");\n requestFocus(edt_name);\n return false;\n } else if (phone.isEmpty()) {\n edt_phone.setError(\"Please Enter Phone Number \");\n requestFocus(edt_phone);\n return false;\n } else if (phone.length() != 10) {\n edt_phone.setError(\"Please Enter Valid Phone Number \");\n requestFocus(edt_phone);\n return false;\n } else if (address.length() == 0) {\n edt_address.setError(\"Please Enter Address\");\n requestFocus(edt_address);\n return false;\n } else if (city.length() == 0) {\n edt_city.setError(\"Please Enter City Name\");\n requestFocus(edt_city);\n return false;\n } else if (state.length() == 0) {\n edt_state.setError(\"Please Enter State Name\");\n requestFocus(edt_state);\n return false;\n }\n return true;\n }", "public boolean validate() {\n String sDayCheck = sDayView.getText().toString();\n String eDayCheck = eDayView.getText().toString();\n String sTimeCheck = sTimeView.getText().toString();\n String eTimeCheck = eTimeView.getText().toString();\n\n if ((titleView.getText().toString().matches(\"\")) || (roomView.getText().toString().matches(\"\"))) {\n Toast.makeText(getApplicationContext(),\"Please fill in all fields.\",Toast.LENGTH_SHORT).show();\n return false;\n }\n\n if ((sDayCheck.length() != 10) ||\n (eDayCheck.length() != 10) ||\n (sTimeCheck.length() != 5) ||\n (eTimeCheck.length() != 5)) {\n Toast.makeText(getApplicationContext(),\"Please check your Date and Time fields.\",Toast.LENGTH_SHORT).show();\n return false;\n } else if ((sDayCheck.charAt(2) != '/') || (sDayCheck.charAt(5) != '/') ||\n (eDayCheck.charAt(2) != '/') || (eDayCheck.charAt(5) != '/')) {\n Toast.makeText(getApplicationContext(), \"Please check your Date fields.\", Toast.LENGTH_SHORT).show();\n return false;\n } else if ((sTimeCheck.charAt(2) != ':') || (eTimeCheck.charAt(2) != ':')) {\n Toast.makeText(getApplicationContext(), \"Please check your Time fields.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (!endDateAfter(sDayCheck, eDayCheck)) {\n Toast.makeText(getApplicationContext(), \"End date must be on or after the Start date.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (!endTimeAfter(sTimeCheck, eTimeCheck)) {\n Toast.makeText(getApplicationContext(), \"End time must be on or after the Start time.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n if (isOutOfDate(eDayCheck)) {\n Toast.makeText(getApplicationContext(), \"End date must be on or after Today's Date.\", Toast.LENGTH_SHORT).show();\n return false;\n }\n return true;\n }", "@Override\n\tpublic boolean checkInput() {\n\t\treturn true;\n\t}", "private void InputTextValidator () {\n isNotNull = !txtCategoryNo.getText().equals(\"\") && !txtCategoryName.getText().equals(\"\");\n }", "private boolean validateFields() {\r\n\t\tif (txUsuario.getText().equals(\"\") || txPassword.getText().equals(\"\")\r\n\t\t\t\t|| checkAdmin.isIndeterminate()|| checkTPV.isIndeterminate())\r\n\t\t\treturn false;\r\n\t\treturn true;\r\n\t}", "public boolean isValidPart() {\n boolean result = false;\n boolean isComplete = !partPrice.getText().equals(\"\")\n && !partName.getText().equals(\"\")\n && !inventoryCount.getText().equals(\"\")\n && !partId.getText().equals(\"\")\n && !maximumInventory.getText().equals(\"\")\n && !minimumInventory.getText().equals(\"\")\n && !variableTextField.getText().equals(\"\");\n boolean isValidPrice = isDoubleValid(partPrice);\n boolean isValidName = isCSVTextValid(partName);\n boolean isValidId = isIntegerValid(partId);\n boolean isValidMax = isIntegerValid(maximumInventory);\n boolean isValidMin = isIntegerValid(minimumInventory);\n boolean isMinLessThanMax = false;\n if (isComplete)\n isMinLessThanMax = Integer.parseInt(maximumInventory.getText()) > Integer.parseInt(minimumInventory.getText());\n\n if (!isComplete) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Missing Information\");\n errorMessage.setHeaderText(\"You didn't enter required information!\");\n errorMessage.setContentText(\"All fields are required! Your part has not been saved. Press \\\"OK\\\" and try again.\");\n errorMessage.show();\n } else if (!isMinLessThanMax) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Invalid Entry\");\n errorMessage.setHeaderText(\"Min must be less than Max!\");\n errorMessage.setContentText(\"Re-enter your data! Your part has not been saved.Press \\\"OK\\\" and try again.\");\n errorMessage.show();\n } else if (!isValidPrice) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Price is not valid\");\n errorMessage.setHeaderText(\"The value you entered for price is not valid\");\n errorMessage.setContentText(\"Please ensure that the value you have entered does\" +\n \" not include more than one decimal point (.), does not contain any letters, and does not \" +\n \"have more than two digits after the decimal. \");\n errorMessage.show();\n } else if (!isValidName) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Invalid Name\");\n errorMessage.setHeaderText(\"The value you entered for name is not valid.\");\n errorMessage.setContentText(\"Please ensure that the text you enter does not\" +\n \" include any quotation marks,\" +\n \"(\\\"), or commas (,).\");\n errorMessage.show();\n } else if (!isValidId) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Incorrect ID\");\n errorMessage.setHeaderText(\"The value you entered for ID is not valid\");\n errorMessage.setContentText(\"Please ensure that the value you have entered\" +\n \" is a whole number, with no letters, symbols or decimal points. \");\n errorMessage.show();\n } else if (!isValidMax) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Incorrect Max Inventory\");\n errorMessage.setHeaderText(\"The value you entered for Max is not valid\");\n errorMessage.setContentText(\"Please ensure that the value you have entered\" +\n \" is a whole number, with no letters, symbols or decimal points. \");\n errorMessage.show();\n } else if (!isValidMin) {\n Alert errorMessage = new Alert(Alert.AlertType.INFORMATION);\n errorMessage.setTitle(\"Incorrect Min Inventory\");\n errorMessage.setHeaderText(\"The value you entered for Min is not valid\");\n errorMessage.setContentText(\"Please ensure that the value you have entered\" +\n \" is a whole number, with no letters, symbols or decimal points. \");\n errorMessage.show();\n } else {\n result = true;\n }\n\n return result;\n }", "private static Boolean validateForm() {\n\t\t\tBoolean valid = true;\n\t\t\tSystem.out.println(\"Index: \"+portfolio.findByCode(pCode.getText()));\n\t\t\tif(pCode.getText().equals(\"\")) {\n\t\t\t\tmsgCode.setText(\"Project code is required\");\n\t\t\t\tvalid = false;\n\t\t\t} else if(portfolio.findByCode(pCode.getText()) >= 0) {\n\t\t\t\tmsgCode.setText(\"Project already exists!\");\n\t\t\t\tvalid = false;\n\t\t\t} else {\n\t\t\t\tmsgCode.setText(\"\");\n\t\t\t}\n\t\t\t\n\t\t\tif(pName.getText().equals(\"\")) {\n\t\t\t\tmsgName.setText(\"Project Name is required!\");\n\t\t\t\tvalid = false;\n\t\t\t} else {\n\t\t\t\tmsgName.setText(\"\");\n\t\t\t}\n\t\t\t\n\t\t\tif(pClient.getText().equals(\"\")) {\n\t\t\t\tmsgClient.setText(\"Client is required!\");\n\t\t\t\tvalid = false;\n\t\t\t} else {\n\t\t\t\tmsgClient.setText(\"\");\n\t\t\t}\n\t\t\t\n\t\t\tif(pSDate.getText().equals(\"\")) {\n\t\t\t\tmsgSDate.setText(DATE_FORMAT + \" Start Date is required\");\n\t\t\t\tvalid = false;\n\t\t\t} else {\n\t\t\t\tmsgSDate.setText(DATE_FORMAT);\n\t\t\t}\n\t\t\t\n\t\t\tswitch(pType) {\n\t\t\tcase \"o\":\n\t\t\t\tif(pDeadline.getText().equals(\"\")) {\n\t\t\t\t\tmsgDeadline.setText(DATE_FORMAT + \" Deadline is required!\");\n\t\t\t\t\tvalid = false;\n\t\t\t\t} else {\n\t\t\t\t\tmsgDeadline.setText(DATE_FORMAT);\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\ttry {\n\t\t\t\t\tDouble b = Double.parseDouble(pBudget.getText());\n\t\t\t\t\tif(b<0) {\n\t\t\t\t\t\tmsgBudget.setText(\"Must be a positive value\");\n\t\t\t\t\t\tvalid=false;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tmsgBudget.setText(\"\");\n\t\t\t\t\t}\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\tmsgBudget.setText(\"Invalid number!\");\n\t\t\t\t\tvalid = false;\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\ttry {\n\t\t\t\t\tint c = Integer.parseInt(pCompletion.getText());\n\t\t\t\t\tif(c<0 || c>100) {\n\t\t\t\t\t\tmsgCompletion.setText(\"Value must be between 0 and 100\");\n\t\t\t\t\t\tvalid = false;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tmsgCompletion.setText(\"\");\n\t\t\t\t\t}\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\tmsgCompletion.setText(\"Invalid number!\");\n\t\t\t\t\tvalid = false;\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\tbreak;\n\t\t\t\t\n\t\t\tcase \"f\":\n\t\t\t\tif(pEndDate.getText().equals(\"\")) {\n\t\t\t\t\tmsgEndDate.setText(DATE_FORMAT + \" End date is required!\");\n\t\t\t\t\tvalid = false;\n\t\t\t\t} else {\n\t\t\t\t\tmsgEndDate.setText(DATE_FORMAT);\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\ttry {\n\t\t\t\t\tDouble b = Double.parseDouble(pTotalCost.getText());\n\t\t\t\t\tif(b<0){\n\t\t\t\t\t\tmsgTotalCost.setText(\"Must be a positive number\");\n\t\t\t\t\t\tvalid=false;\n\t\t\t\t\t} else {\n\t\t\t\t\t\tmsgTotalCost.setText(\"\");\n\t\t\t\t\t}\n\t\t\t\t} catch (Exception e) {\n\t\t\t\t\tmsgTotalCost.setText(\"Invalid number!\");\n\t\t\t\t\tvalid = false;\n\t\t\t\t}\n\t\t\t\t\n\t\t\t}\n\t\t\treturn valid;\n\t\t}", "private boolean isValid(){\n if(txtFirstname.getText().trim().isEmpty() || txtLastname.getText().trim().isEmpty() ||\n txtEmailAddress.getText().trim().isEmpty() || dobPicker.getValue()==null\n || txtPNum.getText().trim().isEmpty()\n || txtDefUsername.getText().trim().isEmpty()\n || curPassword.getText().trim().isEmpty()){\n \n return false; // return false if one/more fields are not filled\n }else{\n if(!newPassword.getText().trim().isEmpty()){\n if(!confirmPassword.getText().trim().isEmpty()){\n return true;\n }else{\n return false;\n }\n }\n return true; // return true if all fields are filled\n }\n }", "private boolean validateInput() {\n\tboolean valid = false;\n\ttry {\n\t if (paymentText == null | paymentText.getValue() == \"\") {\n\t\tpaymentText.focus();\n\t\tthrow new NullPointerException(\"paymentText fehlt\");\n\t }\n\t if (paymentBetrag == null | paymentBetrag.getValue() == \"\") {\n\t\tpaymentBetrag.focus();\n\t\tthrow new NullPointerException(\"paymentBetrag fehlt\");\n\t }\n\t if (!paymentBetrag.isEmpty()) {\n\t\t@SuppressWarnings(\"unused\")\n\t\tdouble d = Double.parseDouble(paymentBetrag.getValue());\n\t }\n\t // seems that everything was OK\n\t valid = true;\n\t} catch (NullPointerException e) {\n\t System.out.println(\"PaymentWindow - \" + e);\n\t} catch (NumberFormatException e) {\n\t // entered value is no number\n\t paymentBetrag.focus();\n\t}\n\treturn valid;\n }", "private boolean checkfields() {\n try {\n Integer.parseInt(checknum.getText().toString());\n Integer.parseInt(banknum.getText().toString());\n Integer.parseInt(branchnum.getText().toString());\n Integer.parseInt(accountnum.getText().toString()); //was commented\n\n } catch (NumberFormatException e) { // at least one of these numbers is not Integer\n return false;\n }\n\n if (checknum.getText().toString().equals(null) || banknum.getText().toString().equals(null) ||branchnum.getText().toString().equals(null)|| accountnum.getText().toString().equals(null))\n return false; // At least one of the fields is empty\n\n return true;\n }", "public boolean validation(){\n String Venuename= venuename.getText().toString();\n String Address= address.getText().toString();\n String Details= details.getText().toString();\n String Venueimage= venueimage.getText().toString();\n if(Venuename.isEmpty()){\n venuename.setError(\"Please enter the item name\");\n venuename.requestFocus();\n return false;\n }\n if(Address.isEmpty()){\n address.setError(\"Please enter the item name\");\n address.requestFocus();\n return false;\n }\n if(Details.isEmpty()){\n details.setError(\"Please enter the item name\");\n details.requestFocus();\n return false;\n }\n if(Venueimage.isEmpty()){\n venueimage.setError(\"Please Select the image first\");\n return false;\n }\n\n\n return true;\n }", "private boolean isInputValid() {\n String errorMessage = \"\";\n\n if (ID.getText() == null || ID.getText().length() == 0) {\n errorMessage += \"No valid id!\\n\";\n System.out.println(\"fl\");\n }\n if (password.getText() == null || password.getText().length() == 0) {\n errorMessage += \"No valid password!\\n\"; \n }\n if (errorMessage.length() == 0) {\n return true;\n } else {\n // Show the error message.\n Dialogs.create()\n .title(\"Invalid Fields\")\n .masthead(\"Please correct invalid fields\")\n .message(errorMessage)\n .showError();\n return false;\n }\n }", "public void validate(){\r\n\t\ttry{\r\n\t\t\t//First name, last name, date of birth and email are compulsory.\r\n\t\tif(FirstName==null||LastName==null||Dob==null||Email==null) \r\n\t\t\tthrow new Exception(\"One of the field is Empty :\\n(First name / last name / dob / email )\");\r\n\t\tif(TelephoneNumber!=0||MobileNumber!=0)\r\n\t\t\tthrow new Exception(\"Enter Contact Number\");\r\n\t\t\r\n\t\t}\r\n\t\tcatch(Exception e){\r\n\t\t\tSystem.out.println(e);\r\n\t\t}\r\n\t\t\r\n\t\t/*finally{\r\n\t\t\tSystem.out.println(\"Program Executed\");\r\n\t\t}*/\r\n\t}", "private boolean fieldsAreFilled(){\n return !textboxName.isEnabled() && !textboxInitialValue.isEnabled();\n }", "public boolean checkFields(){\n String message = \"\";\n if (firstName.getText().isEmpty()){\n message=\"First name is required\";\n }\n if (lastName.getText().isEmpty()){\n if (message.isEmpty())\n message = \"Last name is required\";\n else\n message = \"First name and Last name are required\";\n }\n if (birthday.getValue() == null){\n if (message.isEmpty())\n message = \"please select your birthday\";\n else if (firstName.getText().isEmpty()&& !lastName.getText().isEmpty())\n message = \"First name and birthday required\";\n else if (!firstName.getText().isEmpty() && lastName.getText().isEmpty())\n message = \"Last name and birthday required\";\n else\n message = \"all fields are required\";\n }\n errorDisplay.setText(message);\n return message.equals(\"\");\n }", "private boolean isInputValid(){\n boolean isUserInfoValid = userInfoCheck();\n boolean isProductInfoValid = productInfoCheck();\n ImageView iv_error_user_info = findViewById(R.id.iv_error_user_info);\n ImageView iv_error_product_info = findViewById(R.id.iv_error_product_info);\n if(!isUserInfoValid){\n iv_error_user_info.setVisibility(View.VISIBLE);\n }else{\n iv_error_user_info.setVisibility(View.INVISIBLE);\n }\n if (!isProductInfoValid){\n iv_error_product_info.setVisibility(View.VISIBLE);\n }else{\n iv_error_product_info.setVisibility(View.INVISIBLE);\n }\n\n return isUserInfoValid && isProductInfoValid;\n }", "private boolean formValidated() {\n boolean flag = true;\n name_error.setVisibility(View.GONE);\n family_error.setVisibility(View.GONE);\n address_region_error.setVisibility(View.GONE);\n address_city_error.setVisibility(View.GONE);\n address_error.setVisibility(View.GONE);\n gender_error.setVisibility(View.GONE);\n cellphone_error.setVisibility(View.GONE);\n address_postal_code_error.setVisibility(View.GONE);\n if (address_spinner.getSelectedItem() == null || address_spinner.getSelectedItem().equals(getString(R.string.address_province_placeholder))) {\n address_region_error.setVisibility(View.VISIBLE);\n address_region_error.setText(R.string.error_isrequired);\n flag = false;\n }\n if (city_spinner.getVisibility() == View.VISIBLE && (city_spinner.getSelectedItem() == null || city_spinner.getSelectedItem().equals(getString(R.string.address_city_placeholder)))) {\n address_city_error.setVisibility(View.VISIBLE);\n address_city_error.setText(R.string.error_isrequired);\n flag = false;\n }\n if (postal_spinner.getVisibility() == View.VISIBLE && (postal_spinner.getSelectedItem() == null || postal_spinner.getSelectedItem().equals(getString(R.string.delivery_neighbourhood)))) {\n address_postal_region_error.setVisibility(View.VISIBLE);\n address_postal_region_error.setText(R.string.error_isrequired);\n flag = true;\n }\n if (BamiloApplication.CUSTOMER.getGender().isEmpty()) {\n if (gender_spinner.getSelectedItem() == null || gender_spinner.getSelectedItem().equals(getString(R.string.gender))) {\n gender_error.setVisibility(View.VISIBLE);\n gender_error.setText(R.string.error_isrequired);\n flag = false;\n }\n }\n if (name.getText().length() >= 0) {\n /* */\n if (name.getText().length() < 2) {\n name_error.setVisibility(View.VISIBLE);\n name_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n if (family.getText().length() >= 0) {\n /* */\n if (family.getText().length() < 2) {\n family_error.setVisibility(View.VISIBLE);\n family_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n if (address.getText().length() >= 0) {\n /* */\n if (address.getText().length() < 2) {\n address_error.setVisibility(View.VISIBLE);\n address_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n }\n Pattern pattern = Pattern.compile(getString(R.string.cellphone_regex), Pattern.CASE_INSENSITIVE);\n\n Matcher matcher = pattern.matcher(cellphone.getText());\n boolean result = matcher.matches();\n if (!result) {\n cellphone.setVisibility(View.VISIBLE);\n cellphone_error.setVisibility(View.VISIBLE);\n cellphone_error.setText(R.string.address_phone_number_invalidity_error);\n flag = false;\n }\n if (cellphone.getText().length() == 0) {\n cellphone.setVisibility(View.VISIBLE);\n cellphone_error.setVisibility(View.VISIBLE);\n cellphone_error.setText(R.string.error_isrequired);\n flag = false;\n }\n\n\n if (postal_code.getText().length() != 0 && postal_code.getText().length() != 10) {\n address_postal_code_error.setVisibility(View.VISIBLE);\n flag = false;\n }\n\n if (gender_lable.length() == 0) {\n gender_error.setVisibility(View.VISIBLE);\n flag = false;\n }\n return flag;\n }", "private boolean checkInputField(String price) {\n if (productName.isEmpty() || price.isEmpty()) {\n final AlertDialog alertDialog = new AlertDialog.Builder(EditProductActivity.this).create();\n alertDialog.setTitle(\"Not all fields filled in\");\n alertDialog.setCancelable(true);\n alertDialog.setMessage(\"Please fill in all fields first\");\n alertDialog.setButton(AlertDialog.BUTTON_NEGATIVE, \"ok\", (dialog, which) -> alertDialog.dismiss());\n alertDialog.show();\n return false;\n }\n return true;\n }", "public void validateSchedular() {\n boolean startDateCheck = false, cronTimeCheck = false, dateFormatCheck = false;\n /*\n Schedular Properties\n */\n\n System.out.println(\"Date: \" + startDate.getValue());\n if (startDate.getValue() != null) {\n System.out.println(\"Date: \" + startDate.getValue());\n startDateCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". Start Date should not be empty.\\n\");\n }\n\n if (!cronTime.getText().isEmpty()) {\n cronTimeCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". Cron Time should not be empty.\\n\");\n }\n// if (!dateFormat.getText().isEmpty()) {\n// dateFormatCheck = true;\n// } else {\n// execptionData.append((++exceptionCount) + \". Date Format should not be empty.\\n\");\n// }\n\n if (startDateCheck == true && cronTimeCheck == true) {\n schedularCheck = true;\n } else {\n schedularCheck = false;\n startDateCheck = false;\n cronTimeCheck = false;\n dateFormatCheck = false;\n }\n\n }", "public boolean validateData(){\n boolean dataOk=true;\n if (etName.getText().toString().equals(\"\")){\n Log.i(\"ProfileEditActivity\",\"Name field is void.\");\n dataOk=false;\n }\n if (etSurname.getText().toString().equals(\"\")){\n Log.i(\"ProfileEditActivity\",\"Surname field is void.\");\n dataOk=false;\n }\n if (etDescription.getText().toString().equals(\"\")){\n Log.i(\"ProfileEditActivity\",\"Description field is void.\");\n dataOk=false;\n }\n return dataOk;\n }", "private boolean validateInputs(String iStart, String iEnd, String country, String type) {\n \thideErrors();\n \tint validStart;\n \tint validEnd;\n boolean valid = true;\n// \t//will not occur due to UI interface\n// if (isComboBoxEmpty(type)) {\n// \tvalid = false;\n// \tT3_type_error_Text.setVisible(true);\n// }\n if (isComboBoxEmpty(country)) {\n \tvalid = false;\n \tT3_country_error_Text.setVisible(true);\n }\n \t//checking if start year and end year are set\n if (isComboBoxEmpty(iStart)){\n //start is empty\n T3_start_year_error_Text.setVisible(true);\n valid = false;\n }\n if (isComboBoxEmpty(iEnd)){\n //end is empty\n T3_end_year_error_Text.setVisible(true);\n valid = false;\n }\n \tif (valid){\n //if years are not empty and valid perform further testing\n \t\t//fetch valid data range\n \tPair<String,String> validRange = DatasetHandler.getValidRange(type, country);\n \tvalidStart = Integer.parseInt(validRange.getKey());\n \tvalidEnd = Integer.parseInt(validRange.getValue());\n //check year range validity\n \t\tint start = Integer.parseInt(iStart);\n \t\tint end = Integer.parseInt(iEnd);\n \tif (start>=end) {\n \t\tT3_range_error_Text.setText(\"Start year should be < end year\");\n \t\tT3_range_error_Text.setVisible(true);\n \t\tvalid=false;\n \t}\n// \t//will not occur due to UI interface\n// \telse if (start<validStart) {\n// \t\tT3_range_error_Text.setText(\"Start year should be >= \" + Integer.toString(validStart));\n// \t\tT3_range_error_Text.setVisible(true);\n// \t\tvalid=false;\n// \t}else if (end>validEnd) {\n// \t\tT3_range_error_Text.setText(\"End year should be <= \" + Integer.toString(validEnd));\n// \t\tT3_range_error_Text.setVisible(true);\n// \t\tvalid=false;\n// \t}\n \t}\n// \t//will not occur due to UI interface\n// \tif(isComboBoxEmpty(type)) {\n// \t\t//if type is not set\n// T3_type_error_Text.setVisible(true);\n// \t}\n \t\n if(isComboBoxEmpty(country)) {\n //if country is not set\n T3_country_error_Text.setVisible(true);\n }\n \treturn valid;\n }", "private void validateDate() {\n if (dtpSightingDate.isEmpty()) {\n dtpSightingDate.setErrorMessage(\"This field cannot be left empty.\");\n dtpSightingDate.setInvalid(true);\n removeValidity();\n }\n // Check that the selected date is after research began (range check)\n else if (!validator.checkDateAfterMin(dtpSightingDate.getValue())) {\n dtpSightingDate.setErrorMessage(\"Please enter from \" + researchDetails.MIN_DATE + \" and afterwards. This is when the research period began.\");\n dtpSightingDate.setInvalid(true);\n removeValidity();\n }\n // Check that the selected date is not in the future (range check / logic check)\n else if (!validator.checkDateNotInFuture(dtpSightingDate.getValue())) {\n dtpSightingDate.setErrorMessage(\"Please enter a date from today or before. Sighting date cannot be in the future.\");\n dtpSightingDate.setInvalid(true);\n removeValidity();\n }\n }", "protected abstract boolean checkInput();", "private boolean validateInputs() {\n\n boolean bValid = true;\n\n // Extract the inputs entered by the user and verify them\n String strEmail = m_tfUserEmailID.getText().toString();\n String strPassword = m_tfUserPassword.getText().toString();\n\n // Check if the e-mail format is right\n if (strEmail.isEmpty() || !android.util.Patterns.EMAIL_ADDRESS.matcher(strEmail).matches()) {\n m_tfUserEmailID.setError(\"Enter a valid email address\");\n bValid = false;\n } else {\n m_tfUserEmailID.setError(null);\n }\n\n // Check if the password is at least 6 characters long and within 12 characters\n if (strPassword.isEmpty() || strPassword.length() < 6 || strPassword.length() > 12) {\n m_tfUserPassword.setError(\"Must be between 6-12 alphanumeric characters\");\n bValid = false;\n } else {\n m_tfUserPassword.setError(null);\n }\n\n return bValid;\n }", "private void validate() {\n\t\t// just in case;\n\t\tfor (int i=0;i<NR_OF_FIELDS; i++) {\n\t\t\tvalid[i] = \"0\";\n\t\t}\n\t\t//\n\t\t// Validate name and surname:\n\t\t//\n\t\tif ( ! this.isUpperAlpha(nume)) {\n\t\t\tfields[0] = \"1\";\n\t\t}\n\t\t\n\t\tif ( ! this.isUpperAlphaWithSpace(nume)) {\n\t\t\tfields[1] = \"1\";\n\t\t}\n\t\t//\n\t\t// validate seria\n\t\t//\n\t\tvalid[2] = \"1\";\t\t\t\t\t\t\t// presupun ca seria este invalida, si incerc sa o validez\n\t\tfor (int i=0; i<seriiBuletin.length; i++) {\n\t\t\tif (seriiBuletin[i].equals(seria)) {\n\t\t\t\tvalid[2] = \"0\";\n\t\t\t}\n\t\t}\n\t\t//\n\t\t// validate numarul\n\t\t//\n\t\ttry {\n\t\t\tvalid[3] = \"1\";\n\t\t\tint nr = Integer.valueOf(numarul);\n\t\t\tif ( nr >= 100000 && nr <= 999999 ) {\n\t\t\t\tvalid[3] = \"0\";\n\t\t\t}\n\t\t} catch (Exception e) {\n\t\t\tLog.d(TAG, \"Error validating seria.\");\n\t\t}\n\n\t\t//\n\t\t// validate sex\n\t\t//\n\t\tif ( ! (sex == 'M' || sex == 'F')) {\n\t\t\tvalid[6] = \"1\";\n\t\t}\n\t\t//\n\t\t// Validate valabilitate\n\t\t//\n\t\tif ( ! isNumber(this.valabilitate)) {\n\t\t\tvalid[7] = \"1\";\n\t\t}\n\t\t//\n\t\t// validate CNP\n\t\t//\n\t\tif ( ! (isNumber(CNP) && isValidCNP(CNP))) {\n\t\t\tvalid[8] = \"1\";\n\t\t}\n\t\t\n\t}", "private Boolean validarEntradas(){\n edtTxCdPrd = findViewById(R.id.edtTxCdPrd);\n edtTxDcr = findViewById(R.id.edtTxDcr);\n edtTxPrecVnd = findViewById(R.id.edtTxPrecVnd);\n boolean vldc = true;\n if (edtTxCdPrd.getText().toString().equals(\"\")){\n vldc = false;\n }\n if (edtTxDcr.getText().toString().equals(\"\")){\n vldc = false;\n }\n if (edtTxPrecVnd.getText().toString().equals(\"\")){\n vldc = false;\n }\n return vldc;\n }", "private void checkValidation() {\n String getInstituteName = NameofInstitute.getText().toString();\n String getDegreename = SpinnerDegree.getSelectedItem().toString();\n\n\n // Check if all strings are null or not\n if (getInstituteName.equals(\"\") || getInstituteName.length() == 0 || getDegreename.equals(\"\") || getDegreename.length() == 0)\n new CustomToast().Show_Toast(getActivity(), getView(),\"All fields are required.\");\n // Else do signup or do your stuff\n else {\n //Toast.makeText(getActivity(), \"All Ok till Now\", Toast.LENGTH_SHORT).show();\n AddQualifications(getDegreename,getInstituteName);\n }\n\n }", "private boolean validateInput(EditText titleInput, EditText descriptionInput, EditText priceInput) {\n String title = titleInput.getText().toString();\n String description = descriptionInput.getText().toString();\n int price = (TextUtils.isEmpty(priceInput.getText().toString()))? -1 : Integer.parseInt(priceInput.getText().toString());\n if (TextUtils.isEmpty(title) || TextUtils.isEmpty(description) || price < 0) {\n Toast.makeText(this.getActivity(),\n \"Please, fill in all fields.\",\n Toast.LENGTH_LONG).show();\n return false;\n }\n if (photoURI == null) {\n Toast.makeText(this.getActivity(),\n \"Please, add a picture to this item before submitting it.\",\n Toast.LENGTH_LONG).show();\n return false;\n }\n return true;\n }", "private void validateFields() {\n\t\t// TODO validate ID\n\t\tboolean valid = (mEdtAddress.getText().length() > 2)\n\t\t\t\t&& (mEdtPassword.getText().length() > 0);\n\t\tmBtnNext.setEnabled(valid);\n\t}", "private boolean checkForInvalidInput(){\n String email = emailTextView.getText().toString();\n String password = passwordTextView.getText().toString();\n String name = usernameTextView.getText().toString();\n\n\n if(email.isEmpty() || password.isEmpty() || name.isEmpty()){\n Toast.makeText(getApplicationContext(),\"Please fill in all fields\", Toast.LENGTH_LONG).show();\n return false;\n }\n\n\n if(!email.contains(\"@\")){\n Toast.makeText(getApplicationContext(),\"Please enter a valid email\", Toast.LENGTH_LONG).show();\n return false;\n }\n\n if(!isStudent && !isTeacher){\n Toast.makeText(getApplicationContext(),\"Please select Student or Teacher\", Toast.LENGTH_LONG).show();\n return false;\n }\n\n\n\n\n\n // add more checks?\n\n return true;\n\n }", "public boolean validate() {\n boolean valid = true;\n //Is mName ET not empty and fit mName requirements\n if (mValidation.isInputEditTextFilled(mNameText, getString(R.string.name_empty))) {\n if (!mValidation.isInputEditTextName(mNameText, getString(R.string.name_empty))) {\n valid = false;\n }\n } else {\n valid = false;\n }\n //Is mEmail ET not empty and fit mEmail requirements\n if (mValidation.isInputEditTextFilled(mEmailText, getString(R.string.email_empty))) {\n if (!mValidation.isInputEditTextEmail(mEmailText, getString(R.string.enter_valid_email))) {\n valid = false;\n }\n } else {\n valid = false;\n }\n //Is mPassword ET not empty and fit mPassword requirements\n if (mValidation.isInputEditTextFilled(mPasswordText, getString(R.string.password_empty))) {\n if (!mValidation.isInputEditTextPassword(mPasswordText, getString(R.string.password_requirements))) {\n valid = false;\n }\n } else {\n valid = false;\n }\n //Is confirmPassword ET not empty and fit confirmPassword requirements\n if (mValidation.isInputEditTextFilled(mConfirmPasswordText, getString(R.string.password_confirmation_empty))) {\n if (!mValidation.isInputEditTextMatches(mPasswordText, mConfirmPasswordText, getString(R.string.password_doesnt_match))) {\n valid = false;\n }\n } else {\n valid = false;\n }\n return valid;\n }", "private boolean checkValid() {\n\t\tif(openRadio.isSelected()) {\n\t\t\t//Open loop mode.\n\t\t\treturn checkInfusionRate() && checkPumpSelected() && checkMonitorSelected();\n\t\t} else {\n\t\t\t//Closed loop mode.\n\t\t\t//Check patient selected\n\t\t\t//Check QCore selected\n\t\t\t//Check BP monitor selected\n\t\t\t//Check target BP range\n\t\t\t//Check infusion rate.\n\t\t\treturn checkTargetBPRange() && checkInfusionRate() && checkPumpSelected() && checkMonitorSelected();\n\t\t}\n\t}", "private void validateData() {\n }", "public boolean validateuser(){\n if(fname.getText().toString().isEmpty()){\n fname.setError(\"Enter your first name\");\n fname.requestFocus();\n return false;\n }\n if(lname.getText().toString().isEmpty()){\n lname.setError(\"Enter your last name\");\n lname.requestFocus();\n return false;\n }\n if(username.getText().toString().isEmpty()){\n username.setError(\"Enter your last name\");\n username.requestFocus();\n return false;\n }\n if(password.getText().toString().isEmpty()||password.getText().toString().length()<6){\n password.setError(\"Enter your password with digit more than 6\");\n password.requestFocus();\n return false;\n }\n return true;\n }", "private boolean userInfoCheck(){\n boolean isValid = true;\n EditText et_user_name = findViewById(R.id.et_client_fName);\n EditText et_user_location = findViewById(R.id.et_client_sName);\n if(et_user_name.getText().toString().trim().isEmpty()){\n et_user_name.setError(\"Name Cannot Be Empty\");\n isValid = false;\n }\n if (et_user_location.getText().toString().trim().isEmpty()){\n et_user_location.setError(\"Location Cannot Be Empty\");\n isValid = false;\n }\n return isValid;\n }", "private boolean checkData() {\n if (txtMaMay.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(this, \"Mã máy không được để trống!\\n\"\n + \"Quy tắc đặt tên mã máy: số hiệu máy+mã phòng\");\n return false;\n } else if (txtcauhinh.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(this, \"Cấu hình máy không được để trống!\");\n return false;\n } else if (txtTinhtrang.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(this, \"Tình trạng máy không được để trống!\");\n return false;\n } else if (txtphanmem.getText().equals(\"\")) {\n JOptionPane.showMessageDialog(this, \"Mã phòng không được để trống!\");\n return false;\n }\n return true;\n }", "protected boolean isValidData() {\n return true;\n }", "protected boolean isAllRequiredTxtFieldsFilled() {\r\n JTextField[] txtFields = {\r\n txtFieldFirstName, txtFieldLastName,\r\n txtFieldDateOfBirth, txtFieldIBAN,\r\n txtFieldState, txtFieldHouseNumber,\r\n txtFieldPostcode, txtFieldLocation,\r\n txtFieldCountry, txtFieldState\r\n };\r\n\r\n for (JTextField txtField : txtFields) {\r\n if (txtField.getText().equals(\"\")) {\r\n return false;\r\n }\r\n }\r\n\r\n return true;\r\n }", "public void validateUIStatus() {\n\n boolean timeZoneCheck = false, timeFormatCheck = false, fetchTimeCheck = false, statusPathCheck = false;\n\n if (!timeZone.getText().isEmpty()) {\n timeZoneCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". Time zone should not be Empty.\\n\");\n }\n if (!statusPath.getText().isEmpty()) {\n statusPathCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". Status File should not be empty.\\n\");\n }\n if (!fetchTime.getText().isEmpty()) {\n fetchTimeCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". UI Refresh Time should not be empty.\\n\");\n }\n if (!timeFormat.getText().isEmpty()) {\n timeFormatCheck = true;\n } else {\n execptionData.append((++exceptionCount) + \". UI Date & Time format should not be Empty.\\n\");\n }\n\n if (timeFormatCheck == true && timeZoneCheck == true && fetchTimeCheck == true && statusPathCheck == true) {\n uiStatusCheck = true;\n } else {\n\n uiStatusCheck = false;\n timeZoneCheck = false;\n timeFormatCheck = false;\n fetchTimeCheck = false;\n statusPathCheck = false;\n }\n }", "private boolean validateFields(){ \n ImplLogger.enterMethod(); \n StringBuffer validationMessage = new StringBuffer();\n boolean isValidationPassed = true;\n if(!ImplValidationUtils.isAlphaSpace(pharmaNameTextField.getText())){\n validationMessage.append(ImplConst.VALIDATE_NAME);\n validationMessage.append(ImplConst.NEXT_LINE);\n pharmaNameTextField.setBackground(Color.red);\n isValidationPassed = false;\n } \n if(!ImplValidationUtils.isAlphabetOnly(userNameTextField.getText())){\n validationMessage.append(ImplConst.VALIDATE_USERNAME);\n validationMessage.append(ImplConst.NEXT_LINE);\n userNameTextField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if(ImplCommonUtil.isUserNameExist(userNameTextField.getText())){\n validationMessage.append(ImplConst.VALIDATE_USERNAME_EXIST);\n validationMessage.append(ImplConst.NEXT_LINE);\n userNameTextField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if(!ImplValidationUtils.isInteger(contactTextField.getText())){\n validationMessage.append(ImplConst.VALIDATE_CONTACT);\n validationMessage.append(ImplConst.NEXT_LINE);\n contactTextField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if(!ImplValidationUtils.isInteger(zipCodeTextField.getText())){\n validationMessage.append(ImplConst.VALIDATE_ZIPCODE);\n validationMessage.append(ImplConst.NEXT_LINE);\n zipCodeTextField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if(ImplValidationUtils.isStringEmptyOrNull(passwordField.getText())){\n validationMessage.append(ImplConst.VALIDATE_PASSWORD);\n validationMessage.append(ImplConst.NEXT_LINE);\n passwordField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if(ImplValidationUtils.isStringEmptyOrNull(confirmPasswordField.getText())){\n validationMessage.append(ImplConst.CONFIRM_VALIDATE_PASSWORD);\n validationMessage.append(ImplConst.NEXT_LINE);\n confirmPasswordField.setBackground(Color.red);\n isValidationPassed = false;\n }\n if (!ImplValidationUtils.isStringEmptyOrNull(confirmPasswordField.getText()) && !confirmPasswordField.getText().equals(passwordField.getText())){\n validationMessage.append(ImplConst.CONFIRM_VALIDATE_PASSWORD);\n validationMessage.append(ImplConst.NEXT_LINE);\n isValidationPassed = false; \n }\n if(!isValidationPassed){\n JOptionPane.showMessageDialog(null,validationMessage);\n } \n ImplLogger.exitMethod();\n return isValidationPassed;\n }", "private boolean validateData() {\n boolean validData = true;\n\n String email = mUserEmail.getText().toString().trim();\n String name = mUserName.getText().toString().trim();\n String password = mUserPassword.getText().toString();\n\n // If the Name text field is empty or Name is less then 3 characters,\n // give user a error message\n if (TextUtils.isEmpty(name) || name.length() < 3) {\n mUserNameWrapper.setError(getString(R.string.text_layout_invalid_name));\n validData = false;\n } else {\n mUserNameWrapper.setErrorEnabled(false);\n }\n\n // If the email text field is empty or email address is not per EMAIL_ADDRESS pattern,\n // give user a error message\n if (TextUtils.isEmpty(email) || !android.util.Patterns.EMAIL_ADDRESS.matcher(email).matches()) {\n mUserEmailWrapper.setError(getString(R.string.text_layout_invalid_email));\n validData = false;\n } else {\n mUserEmailWrapper.setErrorEnabled(false);\n }\n\n // If the password text field is emory or password is not between 5 and 8 digits,\n // give user a error message\n if (TextUtils.isEmpty(password) || password.length() < 5 || password.length() > 8) {\n mUserPasswordWrapper.setError(getString(R.string.text_layout_invalid_password));\n validData = false;\n } else {\n mUserEmailWrapper.setErrorEnabled(false);\n }\n return validData;\n }", "private boolean validate(){\n return EditorUtils.editTextValidator(generalnformation,etGeneralnformation,\"Type in information\") &&\n EditorUtils.editTextValidator(symptoms,etSymptoms, \"Type in symptoms\") &&\n EditorUtils.editTextValidator(management,etManagement, \"Type in management\");\n }", "public static void validation() {\n\t\tif ((!textFieldName.getText().isEmpty()) && (!textField_FirstName.getText().isEmpty())\n\t\t\t\t&& (!textField_Town.getText().isEmpty()) && (!textField_Town.getText().isEmpty())) {\n\n\t\t\tif ((isValidEmailAddress(textField_Email.getText()) == true)) {\n\t\t\t\ttextField_Email.setBackground(Color.white);\n\t\t\t\tif ((force(textField_Mtp.getText()) > 82)) {\n\t\t\t\t\ttextField_Mtp.setBackground(Color.white);\n\t\t\t\t\tactionGiveServeur();\n\n\t\t\t\t} else {\n\t\t\t\t\tshowMessageDialog(null, \"Votre mot de passe est trop faible\");\n\t\t\t\t\ttextField_Mtp.setText(\"Mot de passe trop simple : changer le \");\n\t\t\t\t\ttextField_Mtp.setBackground(Color.RED);\n\t\t\t\t}\n\t\t\t} else {\n\t\t\t\ttextField_Email.setText(\"Email invalide\");\n\t\t\t\ttextField_Email.setBackground(Color.RED);\n\t\t\t\tshowMessageDialog(null, \"Email est invalide\");\n\t\t\t}\n\t\t} else {\n\n\t\t\tshowMessageDialog(null, \"Certain champs sont vide !\");\n\t\t}\n\t}", "public boolean validations() {\n boolean result = false;\n String nameString = mItemNameEditText.getText().toString().trim();\n String locationString = mItemLocationEditText.getText().toString().trim();\n\n if (nameString.isEmpty() || nameString == null || locationString.isEmpty() || locationString == null || isImageNotPresent()) {\n displayToastMessage(getString(R.string.fields_mandatory_msg));\n return result;\n } else {\n result = true;\n return result;\n }\n }", "private boolean isInputValid() {\n String errorMessage = \"\";\n\n if (gemNameField.getText() == null || gemNameField.getText().length() == 0) {\n errorMessage += \"No valid gem name!\\n\";\n }\n if (gemValueField.getText() == null || gemValueField.getText().length() == 0) {\n errorMessage += \"No valid gem value!\\n\";\n } else {\n // try to parse the gem value into an int.\n try {\n Integer.parseInt(gemValueField.getText());\n } catch (NumberFormatException e) {\n errorMessage += \"No valid gem value (must be an integer)!\\n\";\n }\n }\n if (gemDescripField.getText() == null || gemDescripField.getText().length() == 0) {\n errorMessage += \"No valid gem description!\\n\";\n }\n\n if (errorMessage.length() == 0) {\n return true;\n } else {\n // Show the error message.\n Alert alert = new Alert(Alert.AlertType.ERROR);\n alert.initOwner(dialogStage);\n alert.setTitle(\"Invalid Fields\");\n alert.setHeaderText(\"Please correct invalid fields\");\n alert.setContentText(errorMessage);\n\n alert.showAndWait();\n\n return false;\n }\n }" ]
[ "0.7313417", "0.71822226", "0.71387726", "0.709391", "0.7077869", "0.7066727", "0.70442426", "0.7018639", "0.69686455", "0.69618756", "0.6948806", "0.6927725", "0.6905708", "0.68966794", "0.68701524", "0.68550485", "0.68493307", "0.6799252", "0.6789526", "0.6782191", "0.6776265", "0.6775379", "0.676604", "0.67415434", "0.67406034", "0.668771", "0.6680694", "0.6655864", "0.6651487", "0.66423225", "0.6627996", "0.66276217", "0.66161984", "0.660596", "0.6591877", "0.65564173", "0.6543369", "0.65433353", "0.6542406", "0.6541402", "0.6541182", "0.65408564", "0.65406144", "0.6536599", "0.6535891", "0.6533739", "0.65186995", "0.65159553", "0.6514054", "0.64975685", "0.6474757", "0.6470305", "0.6467347", "0.6459721", "0.6447222", "0.64457226", "0.6428917", "0.64222074", "0.63799167", "0.6376639", "0.637625", "0.6360424", "0.63482857", "0.6339129", "0.6327235", "0.63155985", "0.6314026", "0.6309331", "0.6301757", "0.62979877", "0.62979525", "0.629217", "0.62775004", "0.62700367", "0.6252123", "0.6247167", "0.62439233", "0.62400186", "0.62336797", "0.6229893", "0.62110275", "0.6209843", "0.62007225", "0.6185411", "0.61785495", "0.6177398", "0.6171555", "0.6159482", "0.6158485", "0.6155088", "0.6149587", "0.6149237", "0.61480784", "0.61477643", "0.6142388", "0.6142233", "0.6134724", "0.6132272", "0.6130603", "0.6117737" ]
0.73864627
0
Updates the current measurement database entry. If the measurement is done get the viewModel updated
private void save() { // Get the current measurement final LiveData<Measurement> ldm = mViewModel.getMeasurementById(mMeasurementId); ldm.observe(getViewLifecycleOwner(), new Observer<Measurement>() { @Override public void onChanged(final Measurement measurement) { ldm.removeObserver(this); updateMeasurement(measurement); snackBar("Measurement updated!"); } }); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Update\n void update(Measurement measurement);", "public void updateDataModel() {\n //this.dataModel = new TelemetryChartDataModel();\n this.dataModel.\n setModel(getStartDate(), getEndDate(), selectedProjects, telemetryName, parameters);\n Thread thread = new Thread() {\n @Override\n public void run() {\n dataModel.loadData();\n }\n };\n thread.start();\n }", "@Override\n public void performUpdate() {\n this.getController().getDatabase().updateNumbersTest(\n this.getController().getPatID(), finalTime, 5);\n }", "public void update() {\n\t\tmLast = mNow;\n\t\tmNow = get();\n\t}", "public void update() {\n manager.update();\n }", "public void update(){}", "public void update(){}", "public void updateData() {}", "private void observeViewModel(MeasureListViewModel measureListViewModel, SheetListViewModel sheetListViewModel) {\n measureListViewModel.getMeasuresBySheet(getApplication()).observe(this, new Observer<List<Measure>>() {\n @Override\n public void onChanged(@Nullable List<Measure> measures) {\n if (measures != null && measures.size() != 0) {\n\n if (measuresAdapter == null) {\n\n measuresAdapter = new MeasuresAdapter(getApplicationContext(), beatClickCallback);\n recyclerView.setAdapter(measuresAdapter);\n }\n measuresAdapter.setMeasuresList(measures, getApplicationContext());\n\n// recyclerView.smoothScrollToPosition(measures.size()-1);\n Log.d(\"ADD_MEASURE\", \"updated view\");\n\n }\n }\n });\n\n }", "@Override\n\tpublic void update() {\n\t\tobj.update();\n\t}", "public void update(){\n\t\tSystem.out.println(\"Return From Observer Pattern: \\n\" + theModel.getObserverState() \n\t\t+ \"\\n\");\n\t}", "public void notifyModelUpdated()\n {}", "public void update() {\n tableChanged(new TableModelEvent(this));\n }", "private void update()\n {\n\n Platform.runLater(new Runnable() {\n @Override\n public void run() {\n //System.out.println(\"UPDATE\");\n updateHumanPlayerMoney();\n updateListViewDoctorItems();\n updateListViewHospitalItems();\n updateListViewLogWindow();\n updateListViewComputerPlayer();\n load_figure();\n updateComputerPlayerMoney();\n }\n });\n }", "@Override\n\t\tpublic void update() {\n\n\t\t}", "@Override\n\t\tpublic void update() {\n\n\t\t}", "@Override\n\t\tpublic void update() {\n\n\t\t}", "@Override\n\tpublic void dbUpdate(MovementModel data)\tthrows DAOSysException\t{\n\t\tdbUpdate(data, MovementDAO.UPDATE_STM);\n\t}", "public void updateDataComp() {\n\t\tdataEntryDao.updateDataComp();\n\t}", "void updateModelFromView();", "public void willbeUpdated() {\n\t\t\n\t}", "void updateViewFromModel();", "@Override\r\n public void update() {\r\n this.total = calculateTotal();\r\n }", "public void update(DVDCollection model, int selectedDVD) {\n ArrayList<DVD> theList = model.getDvds();\n tList.setItems(FXCollections.observableArrayList(theList));\n\n DVD d = tList.getSelectionModel().getSelectedItem();\n if (d != null) {\n tField.setText(d.getTitle());\n yField.setText(\"\"+d.getYear());\n lField.setText(\"\"+d.getDuration());\n }\n else {\n tField.setText(\"\");\n yField.setText(\"\");\n lField.setText(\"\");\n }\n tList.getSelectionModel().select(selectedDVD);\n }", "@Override\r\n\tpublic void updateData() {\n\t\t\r\n\t}", "private void notifyMeasurementVersionUpdated(String measurement, int version) {\n Logger.info(LOG_TAG, \"Measurement \" + measurement + \" now at \" + version);\n \n final SQLiteDatabase db = this.helper.getWritableDatabase();\n final ContentValues values = new ContentValues();\n values.put(\"name\", measurement);\n values.put(\"version\", version);\n \n synchronized (measurementVersions) {\n measurementVersions.put(measurement, version);\n }\n \n db.insertWithOnConflict(\"measurements\", null, values, SQLiteDatabase.CONFLICT_IGNORE);\n }", "public void update(Observable observable, Object data) {\n if (observable instanceof StoreWorkerModel) {\n mNamesLayout.removeAllViews();\n fillNamesLayout(getActivity());\n mOverallView.onWorkersChanged();\n }\n\n // the store model has changed, notifying the overall view\n else if (observable instanceof StoreModel) {\n mOverallView.onWorkingTimesChanged();\n }\n }", "public void update() {}", "public void dataUpdated() {\r\n finish = getConfiguration().getTransformTarget() != null;\r\n this.wizardControl.updateView();\r\n }", "@Override\r\n\t\tpublic void update() {\n\t\t\t\r\n\t\t}", "@Override\r\n\t\tpublic void update() {\n\t\t\t\r\n\t\t}", "private void notifyUpdated() {\n if (mChanged) {\n mChanged = false;\n mObserver.onChanged(this);\n }\n }", "@Override\n\tpublic void update() {}", "@Override\n\tpublic void update() {}", "void updateData();", "@Override\r\n\tpublic void update() {\n\t\tsuper.update();\r\n\t}", "protected static void update() {\n\t\tstepsTable.update();\n\t\tactive.update();\n\t\tmeals.update();\n\t\t\n\t}", "@Override\n public void notifyUpdate() {\n Update();\n //Invia all'activity di questo frammento il totale speso per aggiornare la sezione di controllo del budget\n onSendTotSpent.ReceiveTotSpent(contactGiftAdapter.totSpent());\n }", "private void updateUI() {\n if (mCurrentLocation != null) {\n mLatitudeTextView.setText(String.valueOf(mCurrentLocation.getLatitude()));\n mLongitudeTextView.setText(String.valueOf(mCurrentLocation.getLongitude()));\n mLastUpdateTimeTextView.setText(mLastUpdateTime);\n\n localLatitude = Double.parseDouble(mLatitudeTextView.getText().toString());\n localLongtitude = Double.parseDouble(mLongitudeTextView.getText().toString());\n double newDistance = Math.round(gps2m(previousLatitude, previousLongitude, localLatitude, localLongtitude) * 100) / 100.0;\n\n /*\n if (!mStartUpdatesButton.isEnabled()) {\n mMoveTextView.setText(String.valueOf(newDistance) + \" m\");\n totalDistance += newDistance;\n\n mTotalDistanceTextView.setText(String.valueOf(totalDistance) + \"m\");\n }\n previousLatitude = localLatitude != 0 ? localLatitude : previousLongitude;\n previousLongitude = localLongtitude != 0 ? localLongtitude : previousLatitude;\n\n\n if (!mStartUpdatesButton.isEnabled()) {\n double speed = Double.parseDouble(timeToSpeed());\n\n timeslots.add(System.currentTimeMillis());\n userspeeds.add((float) speed);\n float randomspeed = (float)Math.random()*6;\n compspeeds.add(randomspeed);\n mSpeedTextView.setText(String.valueOf(speed) + \"km/h\");\n\n //TODO: change weight\n double calValue = calorieCalculator(weight, timeSingleValue / 3600, speed);\n calValue = Math.round(calValue * 100) / 100;\n calValue = calValue < 0 ? 0 : calValue;\n calValue = calValue > 100 ? 100 : calValue;\n calValue = calValue / 1000;\n mCalTextView.setText(String.valueOf(calValue));\n compDistance += 5*randomspeed/3600*1000;\n int predictedCalories = (int) Math.round((calValue / timeSingleValue)) * 3600;\n mCalPredictTextView.setText(String.valueOf(predictedCalories));\n\n\n if (compDistance > totalDistance) {\n if (status == 0 || status == 1) {\n MediaPlayer mediaPlayer1 = MediaPlayer.create(getApplicationContext(), R.raw.tooslow);\n mediaPlayer1.start();\n status = 2;\n }\n } else {\n if (status == 0 || status == 2) {\n MediaPlayer mediaPlayer2 = MediaPlayer.create(getApplicationContext(), R.raw.toofast);\n mediaPlayer2.start();\n status = 1;\n }\n }\n }\n */\n if (!mStartUpdatesButton.isEnabled()) {\n mMoveTextView.setText(String.valueOf(newDistance) + \" m\");\n totalDistance += newDistance;\n double totalDistanceOutput = Math.round(totalDistance * 100) / 100.0;\n totalDistanceOutput = totalDistanceOutput < 0 ? 0 : totalDistanceOutput;\n mTotalDistanceTextView.setText(String.valueOf(totalDistanceOutput) + \"m\");\n }\n previousLatitude = localLatitude != 0 ? localLatitude : previousLongitude;\n previousLongitude = localLongtitude != 0 ? localLongtitude : previousLatitude;\n if (!mStartUpdatesButton.isEnabled()) {\n double speed = Double.parseDouble(timeToSpeed());\n timeslots.add(System.currentTimeMillis());\n userspeeds.add((float) speed);\n float randomspeed = (float) Math.random() * 2;\n compspeeds.add(randomspeed);\n mSpeedTextView.setText(String.valueOf(speed) + \" km/h\");\n double calValue = calorieCalculator(weight, timeSingleValue / 3600, speed);\n calValue = calValue < 0 ? 0 : calValue;\n calValue = calValue > 100 ? 100 : calValue;\n calValue = calValue / 1000.0 * 60;\n calValue = Math.round(calValue * 100) / 100.0;\n mCalTextView.setText(String.valueOf(calValue) + \" kCal/m\");\n compDistance += 5 * randomspeed / 3600 * 1000;\n double predictedCalories = (calValue / timeSingleValue) * 60;\n predictedCalories = (predictedCalories < 0 || predictedCalories > 100000) ? 0 : predictedCalories;\n mCalPredictTextView.setText(\"~ \" + String.valueOf(predictedCalories) + \" kCal\");\n\n if (compDistance > totalDistance) {\n if (status == 0 || status == 1) {\n MediaPlayer mediaPlayer1 = MediaPlayer.create(getApplicationContext(), R.raw.tooslow);\n mediaPlayer1.start();\n status = 2;\n }\n } else {\n if (status == 0 || status == 2) {\n MediaPlayer mediaPlayer2 = MediaPlayer.create(getApplicationContext(), R.raw.toofast);\n mediaPlayer2.start();\n status = 1;\n }\n }\n }\n }\n }", "public void update() {\n\t}", "public void update() {\n\t}", "public void update() {\n\t}", "public void update() {\n\t}", "@Override\r\n\tpublic void update() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void update() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void update() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void update() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void update() {\n\t\t\r\n\t}", "@Override\n public void update(Observable o, Object arg) {\n if (o instanceof FlightViewModel) {\n FlightAdapter flightAdapter = (FlightAdapter) flightActivityBinding.rvList.getAdapter();\n FlightViewModel viewModel = (FlightViewModel) o;\n flightAdapter.setFlightDataList(viewModel.getAirLineData(), viewModel.getFlightDataList());\n }\n }", "@Override\n\tpublic boolean update() {\n\t\tActuator updated = RuntimeStorage.getMyHttp().get_state_actuator(this);\n\n\t\tif (updated != null) {\n\t\t\tthis.setNumber(updated.getNumber());\n\t\t\tthis.setName(updated.getName());\n\t\t\tthis.setType(updated.getType());\n\t\t\tthis.setValue(updated.getValue(), false);\n\t\t\tthis.setUnit(updated.getUnit());\n\t\t\tthis.setUtime(updated.getUtime());\n\t\t} else\n\t\t\treturn false;\n\t\treturn true;\n\t}", "@Override\n\tpublic void queryUpdate() {\n\t\tneedToUpdate = true;\n\t}", "public void update() {\n }", "public void dataChanged() {\n\t\tif (wijzigInfo)\n\t\t\twijzigInfo();\n\n\t\tsetChanged();\n\t\tnotifyObservers(\"dataChanged\");\n\t}", "@Override\r\n\tpublic void operations() {\n\t\tSystem.out.println(\"update self!\"); \r\n notifyObservers(); \r\n\r\n\t}", "private void updateUI() {\n// if (mCurrentLocation != null) {\n// mLatitudeTextView.setText(String.valueOf(mCurrentLocation.getLatitude()));\n// mLongitudeTextView.setText(String.valueOf(mCurrentLocation.getLongitude()));\n// mLastUpdateTimeTextView.setText(mLastUpdateTime);\n// }\n }", "public void update() {\n\t\tupdate(1);\n\t}", "@Override\n\tpublic void update() { }", "@Override\n\tpublic void update(Observable observable, Object data) {\n\n\t}", "@Override\r\n\tpublic void update() {\r\n\t}", "public final void update(){\n if(waitingToExecute){\n execute();\n waitingToExecute = false;\n }\n }", "@Override\n\tpublic int update(Object model) {\n\t\treturn 0;\n\t}", "public void update() {\r\n\t\tCampLeaseDAO leaseDao = (CampLeaseDAO) getApplicationContext().getBean(\"leaseDaoBean\", CampLeaseDAO.class);\r\n\t\tleaseDao.update(this); // routine now uses leaseDao to get CampLease class\r\n\t}", "public void update()\n\t{\n\t\tsuper.update();\n\t}", "@Override\n public void Update(Model model) {\n\n }", "@FXML\n public void updateBreakfast(){\n //get the selection from the listView\n try{\n //get the selected day from the weeklist\n Days selectedDay = weekList.getSelectionModel().getSelectedItem();\n if (breakfastCombo.getSelectionModel().getSelectedItem() != null){\n Recipe newBreakfastRecipe = breakfastCombo.getSelectionModel().getSelectedItem();\n selectedDay.setBreakfast(newBreakfastRecipe);\n }\n } catch (Exception e) {\n System.out.println(\"Nothing selected\");\n e.printStackTrace();\n }\n weekList.refresh();\n //shopping list is now out of sync with the planner\n plannerOutOfSyncWithShoppingList(true);\n saveMealPlanner();\n }", "@Override\n public void onChanged(Measurement measurement) {\n updateTextViews(measurement.getTimeStamp(),\n measurement.isGi(), measurement.getAmount(),\n measurement.getStress(), measurement.getTired(), measurement.isPhysicallyActivity(),\n measurement.isAlcoholConsumed(), measurement.isIll(), measurement.isMedication(),\n measurement.isPeriod(), measurement.getGlucoseStart(), measurement.getGlucose15(),\n measurement.getGlucose30(), measurement.getGlucose45(), measurement.getGlucose60(),\n measurement.getGlucose75(), measurement.getGlucose90(), measurement.getGlucose105(),\n measurement.getGlucose120()\n );\n }", "@Override\r\n\tpublic void update() {\r\n\r\n\t}", "public void update()\n\t{\n\t\t//update the view's list of movies...\n\t\tthis.getRemoveButton().setEnabled((this.database.getNumberOfMovies()>0));\n\t\tthis.movieList.setListData(this.database.toList());\n\t}", "@FXML\n public void updateDinner(){\n //get the selection from the listView\n try{\n //get the selected day from the weeklist\n Days selectedDay = weekList.getSelectionModel().getSelectedItem();\n if (dinnerCombo.getSelectionModel().getSelectedItem() != null){\n Recipe newDinnerRecipe = dinnerCombo.getSelectionModel().getSelectedItem();\n selectedDay.setDinner(newDinnerRecipe);\n }\n } catch (Exception e) {\n System.out.println(\"Nothing selected\");\n }\n weekList.refresh();\n //shopping list is now out of sync with the planner\n plannerOutOfSyncWithShoppingList(true);\n saveMealPlanner();\n }", "@FXML\n public void updateLunch(){\n //get the selection from the listView\n try{\n //get the selected day from the weeklist\n Days selectedDay = weekList.getSelectionModel().getSelectedItem();\n if (lunchCombo.getSelectionModel().getSelectedItem() != null){\n Recipe newLunchRecipe = lunchCombo.getSelectionModel().getSelectedItem();\n selectedDay.setLunch(newLunchRecipe);\n }\n } catch (Exception e) {\n System.out.println(\"Nothing selected\");\n }\n\n weekList.refresh();\n //shopping list is now out of sync with the planner\n plannerOutOfSyncWithShoppingList(true);\n saveMealPlanner();\n }", "@Override\r\n\tpublic void update() {\n\t}", "@Override\r\n\tpublic void update() {\n\t}", "int updateByPrimaryKey(TemperatureMeasureHitchEvent record);", "public boolean update() {\n if(0==modified) return false;\n \n final int res = modified;\n if( (res&DIRTY_MODELVIEW)!=0 ) {\n setMviMvit();\n }\n modified=0;\n return res!=0;\n }", "public void update() {\n\t\t\n\t}", "@Override\n public void update(Observable o, Object arg) {\n setChanged();\n notifyObservers();\n }", "public void update() {\n\t\tif (c.getResamplingFactor() != 1) return;\n\t\trenderer.getVolume().updateData();\n\t}", "@Override\n\tpublic void dbUpdate(MovementModel data, String updateStm)\tthrows DAOSysException {\n//\t\tMovementModel model = data;\n//\t\tConnection connection = null;\n//\t\tPreparedStatement preparedStm = null;\n//\t\ttry\t{\n//\t\t\tconnection = connectToDB();\n//\t\t\tpreparedStm = connection.prepareStatement(updateStm);\n//\n//\t\t\t/*\tGrab values from persistent fields to store in database\t*/\n//\t\t\tpreparedStm.setString(1, model.getComposer());\n//\n// \t\t\tint rowCount = preparedStm.executeUpdate();\n//\t\t\tif (rowCount == 0)\t{\n// \t\t\t\tthrow new DAOSysException(\n// \t\t\t\t\t\"Failed to store state for Movement <\"\n// \t\t\t\t\t+ model.getCompostionName() + \">\");\n// \t\t\t}\n//\n//\t\t}\tcatch (SQLException sex)\t{\n//\t\t\tthrow new DAOSysException(\n//\t\t\t\t\t\"dbUpdate() SQL Exception <\"\n//\t\t\t\t\t+ sex.getMessage() + \">\");\n//\n//\t\t}\tfinally\t{\n//\t\t\ttry\t{\n//\t\t\t\treleaseAll(null, preparedStm, connection);\n//\t\t\t} catch (Exception ex)\t{\n//\t\t\t\tSystem.err.println(\"Error releasing resources <\" + ex.toString());\n//\t\t\t}\n//\t\t}\n\t}", "private Measurement getMeasurements(){\n Measurement measurement = new Measurement();\n\n //set to date of measurement added\n measurement.setDate(new Date());\n\n //retrieve measurement data from edit texts. if edit text is empty make measurement 0;\n String neckString = neckEditText.getText().toString();\n double neck = (!neckString.equals(\"\")) ? Double.parseDouble(neckString) : 0;\n measurement.setNeck(neck);\n\n String chestString = chestEditText.getText().toString();\n double chest = (!chestString.equals(\"\")) ? Double.parseDouble(chestString) : 0;\n measurement.setChest(chest);\n\n String shoulderString = shoulderEditText.getText().toString();\n double shoulders = (!shoulderString.equals(\"\")) ? Double.parseDouble(shoulderString) : 0;\n measurement.setShoulders(shoulders);\n\n String leftArmString = leftArmEditText.getText().toString();\n double leftArm = (!leftArmString.equals(\"\")) ? Double.parseDouble(leftArmString) : 0;\n measurement.setLeftArm(leftArm);\n\n String rightArmString = rightArmEditText.getText().toString();\n double rightArm = (!rightArmString.equals(\"\")) ? Double.parseDouble(rightArmString) : 0;\n measurement.setRightArm(rightArm);\n\n String leftForearmString = leftForearmEditText.getText().toString();\n double leftForearm = (!leftForearmString.equals(\"\")) ? Double.parseDouble(leftForearmString) : 0;\n measurement.setLeftForearm(leftForearm);\n\n String rightForearmString = rightForearmEditText.getText().toString();\n double rightForearm = (!rightForearmString.equals(\"\")) ? Double.parseDouble(rightForearmString) : 0;\n measurement.setRightForearm(rightForearm);\n\n String waistString = waistEditText.getText().toString();\n double waist = (!waistString.equals(\"\")) ? Double.parseDouble(waistString) : 0;\n measurement.setWaist(waist);\n\n String hipsString = hipsEditText.getText().toString();\n double hips = (!hipsString.equals(\"\")) ? Double.parseDouble(hipsString) : 0;\n measurement.setHips(hips);\n\n String leftLegString = leftLegEditText.getText().toString();\n double leftLeg = (!leftLegString.equals(\"\")) ? Double.parseDouble(leftLegString) : 0;\n measurement.setLeftLeg(leftLeg);\n\n String rightLegString = rightLegEditText.getText().toString();\n double rightLeg = (!rightLegString.equals(\"\")) ? Double.parseDouble(rightLegString) : 0;\n measurement.setRightLeg(rightLeg);\n\n String leftCalfString = leftCalfEditText.getText().toString();\n double leftCalf = (!leftCalfString.equals(\"\")) ? Double.parseDouble(leftCalfString) : 0;\n measurement.setLeftCalf(leftCalf);\n\n String rightCalfString = rightCalfEditText.getText().toString();\n double rightCalf = (!rightCalfString.equals(\"\")) ? Double.parseDouble(rightCalfString) : 0;\n measurement.setRightCalf(rightCalf);\n\n String weightString = weightEditText.getText().toString();\n double weight = (!weightString.equals(\"\")) ? Double.parseDouble(weightString) : 0;\n measurement.setWeight(weight);\n\n String bodyFatString = bodyFatEditText.getText().toString();\n double bodyFat = (!bodyFatString.equals(\"\")) ? Double.parseDouble(bodyFatString) : 0;\n measurement.setBodyFat(bodyFat);\n\n //below variables are should be retrieved from the Shared Preferences.\n int age = mSharedPreferences.getInt(Constants.AGE, 0);\n measurement.setAge(age);\n boolean male = mSharedPreferences.getBoolean(Constants.SEX, true);\n measurement.setMale(male);\n String activityLevel = mSharedPreferences.getString(Constants.ACTIVITY, \"\");\n\n if(activityLevel.equals(getString(R.string.sedentary))){\n measurement.setActivityLevel(Calculators.SEDENTERAY);\n } else if(activityLevel.equals(getString(R.string.light))){\n measurement.setActivityLevel(Calculators.LIGHT);\n }else if(activityLevel.equals(getString(R.string.moderate))){\n measurement.setActivityLevel(Calculators.MODERATE);\n }else if(activityLevel.equals(getString(R.string.very_active))){\n measurement.setActivityLevel(Calculators.VERY_ACTIVE);\n }else if(activityLevel.equals(getString(R.string.extremely_active))){\n measurement.setActivityLevel(Calculators.EXTREMELY_ACTIVE);\n }\n\n double height = mSharedPreferences.getFloat(Constants.HEIGHT,0);\n measurement.setHeight(height);\n\n //if weight is more than 0 use the Calculators class to calculate the rest of the measurement variables\n if(weight > 0){\n measurement.setRestingEnergyExpenditure(Calculators.getRestingEnergyExpenditure(weight, height, age, male));\n measurement.setTotalDailyEnergyExpenditure(Calculators.getTotalDailyEnergyExpenditure(measurement.getRestingEnergyExpenditure(), measurement.getActivityLevel()));\n measurement.setProteinAmount(Calculators.getProteinAmount(weight));\n measurement.setFatAmount(Calculators.getFatAmount(measurement.getTotalDailyEnergyExpenditure()));\n measurement.setCarbAmount(Calculators.getCarbAmount(measurement.getProteinAmount(), measurement.getFatAmount(), measurement.getTotalDailyEnergyExpenditure()));\n measurement.setBMI(Calculators.getBMI(height, weight, true));\n measurement.setBMICategory(Calculators.getBMICatagory(measurement.getBMI()));\n measurement.setWaistToHeightRatio(Calculators.waistToHeightRatio(waist, height));\n measurement.setWITHCategory(Calculators.getWTHCatagory(measurement.getWaistToHeightRatio(), male));\n }\n return measurement;\n }", "@Override\n\tpublic void update(Object data) {\n\t\tbind(data,\"frequencyHz\",frequencyHz.slider);\n\t\tbind(data,\"dampingRatio\",dampingRatio.slider);\n\t\tsuper.update(data);\n\t}", "public void update()\n {\n this.controller.updateAll();\n theLogger.info(\"Update request recieved from UI\");\n }", "public void update() {\n\n }", "public void update() {\n\n }", "@Override\n\tpublic void mpdUpdated(int arg0) {\n\t\t\n\t}", "public void run() {\n if (view.getPauseState() && model.getSelectedNote() != null) {\n this.model.removeNote(model.getSelectedNote());\n this.model.setSelectedNote(null);\n }\n\n view.setAllNotes(model.getMusic());\n view.setLength(model.getDuration());\n view.setTone(model.getTone(model.getNotes()));\n view.setTempo(model.getTempo());\n }", "public void update() {\r\n\t\t\r\n\t}", "@Override\n\tpublic void update() {\n\t}", "@Override\n\tpublic void update() {\n\t}", "@Override\n\tpublic void update() {\n\t}", "public void updateView() {\n if (mData.isEmpty()) {\n Logger.d(TAG, \"The mData is empty\");\n return;\n }\n Set<View> viewSet = mData.keySet(); // keySet() returns [] if map is\n // empty\n Iterator<View> viewIterator = viewSet.iterator();\n if (viewIterator == null) {\n Logger.d(TAG, \"The viewIterator is null\");\n return;\n }\n while (viewIterator.hasNext()) {\n View view = viewIterator.next();\n if (view == null) {\n Logger.d(TAG, \"The view is null\");\n } else {\n Object obj = mData.get(view);\n if (obj == null) {\n Logger.d(TAG, \"The value is null\");\n } else {\n if (obj instanceof ChatsStruct) {\n ChatsStruct chatStruct = (ChatsStruct) obj;\n updateChats(view, chatStruct);\n } else if (obj instanceof InvitationStruct) {\n InvitationStruct inviteStruct = (InvitationStruct) obj;\n updateInvitations(view, inviteStruct);\n } else {\n Logger.d(TAG, \"Unknown view type\");\n }\n }\n }\n }\n }", "public void update(){\r\n }", "@Override\n\tpublic void update() {\n\n\t}", "@Override\n\tpublic void update() {\n\n\t}", "@Override\n\tpublic void update() {\n\n\t}", "@Override\n\tpublic void update() {\n\n\t}", "@Override\n\tpublic void update() {\n\n\t}", "@Override\n\tpublic void update() {\n\n\t}", "public void update(){\n\t\tsetChanged();\n\t\trender();\n\t\tprintTimer();\n\t}", "@Override\n public void update() {\n }", "protected abstract void update();" ]
[ "0.6921897", "0.60287255", "0.6014405", "0.59928036", "0.59631705", "0.59509104", "0.59509104", "0.5926199", "0.5876565", "0.5865083", "0.5852458", "0.5846703", "0.5812052", "0.5800215", "0.5782242", "0.5782242", "0.5782242", "0.5780771", "0.57538253", "0.57367396", "0.57234657", "0.5721901", "0.57017964", "0.56680167", "0.5658163", "0.56514037", "0.56371695", "0.56216997", "0.56125516", "0.5584823", "0.5584823", "0.5582459", "0.5582013", "0.5582013", "0.55493003", "0.55485404", "0.551964", "0.55191994", "0.5509228", "0.5502142", "0.5502142", "0.5502142", "0.5502142", "0.5492597", "0.5492597", "0.5492597", "0.5492597", "0.5492597", "0.54900813", "0.5488594", "0.54884595", "0.54835606", "0.54806095", "0.5465451", "0.5465039", "0.5464719", "0.5462877", "0.54586095", "0.5453442", "0.5451819", "0.54483914", "0.5439963", "0.54398954", "0.5439155", "0.54364663", "0.54261845", "0.54026395", "0.5401293", "0.5397094", "0.539388", "0.5393499", "0.5393499", "0.5376314", "0.53662956", "0.5364555", "0.53612894", "0.53596085", "0.53554016", "0.53510326", "0.534561", "0.53429806", "0.53397745", "0.53397745", "0.5336108", "0.53328425", "0.53227204", "0.5322581", "0.5322581", "0.5322581", "0.53172284", "0.53167737", "0.53147125", "0.53147125", "0.53147125", "0.53147125", "0.53147125", "0.53147125", "0.5311224", "0.53078663", "0.5302821" ]
0.6805313
1
Helper function for faster SnackBar creation
private void snackBar(String msg) { MySnackBar.createSnackBar(Objects.requireNonNull(getContext()), Objects.requireNonNull(getView()), msg); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private void showSnackBar(String message) {\n }", "private void createSnack() {\n }", "public void DisplaySnackBarAboveBar(String message, Boolean setAction) {\n int marginSide = 0;\n int marginBottom = 150;\n Snackbar snackbar = Snackbar.make(\n coordinatorLayout,\n message,\n Snackbar.LENGTH_LONG\n );\n\n if (setAction) {\n snackbar.setAction(\"Share Now\", new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n Intent sendIntent = new Intent();\n sendIntent.setAction(Intent.ACTION_SEND);\n sendIntent.putExtra(Intent.EXTRA_TEXT, \"please visit https://www.noobsplanet.com\");\n sendIntent.setType(\"text/plain\");\n startActivity(Intent.createChooser(sendIntent, \"Send to \"));\n }\n });\n }\n\n View snackbarView = snackbar.getView();\n CoordinatorLayout.LayoutParams params = (CoordinatorLayout.LayoutParams) snackbarView.getLayoutParams();\n params.setMargins(\n params.leftMargin + marginSide,\n params.topMargin,\n params.rightMargin + marginSide,\n params.bottomMargin + marginBottom + 100\n );\n\n snackbarView.setLayoutParams(params);\n snackbar.show();\n }", "public void SnackBarB() {\n Snackbar.make(getWindow().getDecorView().getRootView(),\n \"Cálculos sobre cinemática de rotación.\", Snackbar.LENGTH_LONG).show();\n }", "public static void showSnackBar(Context context, LinearLayout mainLayout, String msg, String btnText, int length){\n Resources resources = context.getResources();\n\n Snackbar snackbar = Snackbar\n .make(mainLayout, msg, length )\n .setAction(resources.getText(R.string.ok), new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n }\n });\n\n // Changing message text color\n snackbar.setActionTextColor(ContextCompat.getColor(context, R.color.home_yellow));\n\n // Changing action button text color\n View sbView = snackbar.getView();\n sbView.setBackgroundColor(ContextCompat.getColor(context, R.color.background_edittext));\n\n TextView textView = (TextView) sbView.findViewById(com.google.android.material.R.id.snackbar_text);\n textView.setTextColor(ContextCompat.getColor(context, R.color.edittext_text));\n textView.setMaxLines(5);\n snackbar.show();\n }", "void onSnackBarActionClicked(int uniqueId, View view);", "private void createSnackbar(String message) {\n Snackbar.make(mLayout, message, Snackbar.LENGTH_LONG).show();\n }", "public void displaySnackBar(View layout,int message,int bgcolor){\n Snackbar snack=null;\n View snackView;\n\n if(message == com.ibeis.wildbook.wildbook.R.string.offline)\n snack=Snackbar.make(layout,message,Snackbar.LENGTH_INDEFINITE);\n else\n snack=Snackbar.make(layout,message,Snackbar.LENGTH_SHORT);\n snackView = snack.getView();\n snackView.setBackgroundColor(bgcolor);\n snack.show();\n }", "protected void showTopSnackBar(String message, int bColor) {\n\n Snackbar snack = Snackbar.make(getWindow().getDecorView().findViewById(android.R.id.content), message, Snackbar.LENGTH_LONG);\n View snackbarView = snack.getView();\n snackbarView.setBackgroundColor(bColor);\n// TextView textView = (TextView) snackbarView.findViewById(com.androidadvance.topsnackbar.R.id.snackbar_text);\n// textView.setTextColor(Color.WHITE);\n// textView.setGravity(Gravity.CENTER_HORIZONTAL);\n// FrameLayout.LayoutParams params =(FrameLayout.LayoutParams)snackbarView.getLayoutParams();\n// params.gravity = Gravity.TOP;\n// snackbarView.setLayoutParams(params);\n snack.show();\n }", "@Override\n public void run() {\n snackbar.setVisibility(View.GONE); //This will remove the View. and free s the space occupied by the View\n }", "private void createToolBar() {\r\n toolbar = new JToolBar();\r\n inbox = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.INBOX_ICON)), \"Maintain Inbox\", \"Maintain Inbox\");\r\n awards = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.AWARDS_ICON)), \"Maintain Awards\", \"Maintain Awards\");\r\n proposal = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.PROPOSAL_ICON)), \"Maintain InstituteProposals\", \"Maintain Institute Proposals\");\r\n proposalDevelopment = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.PROPOSAL_DEVELOPMENT_ICON)), \"Maintain ProposalDevelopment\", \"Maintain Proposal Development\");\r\n rolodex = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.ROLODEX_ICON)), \"Maintain Rolodex\", \"Maintain Rolodex\");\r\n sponsor = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.SPONSOR_ICON)), \"Maintain Sponsor\", \"Maintain Sponsor\");\r\n subContract = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.SUBCONTRACT_ICON)), \"Maintain SubContract\", \"Maintain Subcontract\");\r\n negotiations = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.NEGOTIATIONS_ICON)), \"Maintain Negotiations\", \"Maintain Negotiations\");\r\n buisnessRules = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.BUSINESS_RULES_ICON)), \"Maintain BusinessRules\", \"Maintain Business Rules\");\r\n map = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.MAP_ICON)), \"Maintain Map\", \"Maintain Map\");\r\n personnal = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.PERSONNAL_ICON)), \"Maintain Personal\", \"Maintain Personnel\");\r\n users = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.USERS_ICON)), \"Maintain Users\", \"Maintain Users\");\r\n unitHierarchy = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.UNIT_HIERARCHY_ICON)), \"Maintain UnitHierarchy\", \"Maintain Unit Hierarchy\");\r\n cascade = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.CASCADE_ICON)), \"Cascade\", \"Cascade\");\r\n tileHorizontal = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.TILE_HORIZONTAL_ICON)), \"Tile Horizontal\", \"Tile Horizontal\");\r\n tileVertical = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.TILE_VERTICAL_ICON)), \"Tile Vertical\", \"Tile Vertical\");\r\n layer = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.LAYER_ICON)), \"Layer\", \"Layer\");\r\n \r\n /*Added Icons are Committe,Protocol,Shedule. The Icons are different.Non-availability of standard Icon - Chandrashekar*/\r\n //Added for COEUSQA-2580_Change menu item name from \"Protocol\" to \"IRB Protocol\" on Maintain menu in Premium - Start\r\n /* JM 05-02-2013\r\n irbProtocol = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.PROTOCOL_ICON)), \"Protocol\", \"IRB Protocol\");\r\n \r\n irbProtocolSubmission = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.PROTOCOL_SUBMISSION_BASE_ICON)),\"Protocol Submission\",\"IRB Protocol Submission\");\r\n */\r\n //Added for COEUSQA-2580_Change menu item name from \"Protocol\" to \"IRB Protocol\" on Maintain menu in Premium - End\r\n /* JM 05-02-2013\r\n schedule = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.SCHEDULE_ICON)), \"Schedule\", \"Schedule\");\r\n committee = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.COMMITTEE_ICON)), \"Committee\", \"Committee\");\r\n */\r\n //Added for COEUSQA-2580_Change menu item name from \"Protocol\" to \"IRB Protocol\" on Maintain menu in Premium - Start\r\n //irbProtocolSubmission = new CoeusToolBarButton(new ImageIcon(\r\n // getClass().getClassLoader().getResource(CoeusGuiConstants.PROTOCOL_SUBMISSION_BASE_ICON)),\"Protocol Submission\",\"IRB Protocol Submission\");\r\n //Added for COEUSQA-2580_Change menu item name from \"Protocol\" to \"IRB Protocol\" on Maintain menu in Premium - End\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium start\r\n /* JM 05-02-2013\r\n iacucProtocol = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.IACUC_PROTOCOL_ICON)), \"Protocol\", \"IACUC Protocol\");\r\n \r\n iacucProtocolSubmission = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.IACUC_PROTOCOL_SUBMISSION_BASE_ICON)),\"Protocol Submission\",\"IACUC Protocol Submission\");\r\n */\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium end\r\n \r\n /* JM 4-25-2016 adding new Contact Coeus Help button */\r\n contactCoeusHelp = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.HELP_ICON)), \"Contact Coeus Help\", \"Contact Coeus Help\");\r\n /* JM END */\r\n \r\n exit = new CoeusToolBarButton(new ImageIcon(\r\n getClass().getClassLoader().getResource(CoeusGuiConstants.EXIT_ICON)), \"Exit\", \"Exit\");\r\n \r\n \r\n toolbar.add(inbox);\r\n toolbar.addSeparator();\r\n toolbar.add(awards);\r\n toolbar.add(proposal);\r\n toolbar.add(proposalDevelopment);\r\n toolbar.add(rolodex);\r\n toolbar.add(sponsor);\r\n toolbar.add(subContract);\r\n toolbar.add(negotiations);\r\n toolbar.add(buisnessRules);\r\n toolbar.add(map);\r\n toolbar.add(personnal);\r\n toolbar.add(users);\r\n toolbar.add(unitHierarchy);\r\n \r\n /*Added Icons are Committe,Protocol,Shedule - Chandrashekar*/\r\n /* JM 05-02-2013\r\n toolbar.add(irbProtocol);\r\n toolbar.add(irbProtocolSubmission);\r\n \r\n toolbar.add(schedule);\r\n toolbar.add(committee);\r\n */\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium start\r\n /* JM 05-02-2013\r\n toolbar.add(iacucProtocol);\r\n toolbar.add(iacucProtocolSubmission);\r\n */\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium end\r\n \r\n toolbar.addSeparator();\r\n toolbar.add(cascade);\r\n toolbar.add(tileHorizontal);\r\n toolbar.add(tileVertical);\r\n toolbar.add(layer);\r\n toolbar.addSeparator();\r\n \r\n /* JM 4-25-2016 adding new Contact Coeus Help button */\r\n toolbar.add(contactCoeusHelp);\r\n toolbar.addSeparator();\r\n /* JM END */\r\n \r\n toolbar.add(exit);\r\n \r\n toolbar.setFloatable(false);\r\n setTextLabels(false);\r\n MouseListener pl = new PopupListener();\r\n cpm = new CoeusPopupMenu();\r\n toolbar.addMouseListener(pl);\r\n \r\n inbox.addActionListener(this);\r\n awards.addActionListener(this);\r\n proposal.addActionListener(this);\r\n proposalDevelopment.addActionListener(this);\r\n rolodex.addActionListener(this);\r\n sponsor.addActionListener(this);\r\n subContract.addActionListener(this);\r\n negotiations.addActionListener(this);\r\n buisnessRules.addActionListener(this);\r\n map.addActionListener(this);\r\n personnal.addActionListener(this);\r\n users.addActionListener(this);\r\n unitHierarchy.addActionListener(this);\r\n cascade.addActionListener(this);\r\n tileHorizontal.addActionListener(this);\r\n tileVertical.addActionListener(this);\r\n layer.addActionListener(this);\r\n /*Added Icons are Committe,Protocol,Shedule - Chandrashekar*/\r\n /* JM 05-02-2013\r\n irbProtocol.addActionListener(this);\r\n schedule.addActionListener(this);\r\n committee.addActionListener(this);\r\n irbProtocolSubmission.addActionListener(this);\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium start\r\n iacucProtocol.addActionListener(this);\r\n iacucProtocolSubmission.addActionListener(this); */\r\n //Added for case id COEUSQA-2717 icons for IACUC to Coeus Premium end\r\n \r\n /* JM 4-25-2016 adding new Contact Coeus Help button */\r\n contactCoeusHelp.addActionListener(this);\r\n /* JM END */\r\n \r\n exit.addActionListener(this);\r\n }", "public StatusBar() {\n super();\n super.setPreferredSize(new Dimension(100, 16));\n setMessage(\"Ready\");\n }", "private void showSnackBar(String message) {\n if(getActivity()!=null) {\n Snackbar snackbar = Snackbar.make(getActivity().findViewById(android.R.id.content),\n message, Snackbar.LENGTH_SHORT);\n View sbView = snackbar.getView();\n TextView textView = sbView\n .findViewById(android.support.design.R.id.snackbar_text);\n textView.setTextColor(ContextCompat.getColor(getActivity(), R.color.white));\n snackbar.show();\n }\n }", "public static void showSnackBar(Context context, String msg) {\n\n Snackbar.make(((Activity) context).findViewById(android.R.id.content), \"\" + msg, Snackbar.LENGTH_LONG).show();\n }", "public void showHelp() {\n final Snackbar snackBar = Snackbar.make(findViewById(R.id.mapscontainer),\n \"Select a location by clicking the map. Press go to search your categories.\",\n Snackbar.LENGTH_INDEFINITE);\n\n snackBar.setAction(\"Got it!\", new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n snackBar.dismiss();\n }\n })\n .setActionTextColor(Color.WHITE);\n snackBar.show();\n }", "private SnackbarHelper() {\n\n}", "private void showUndoSnackbar() {\n View view = ((Activity) this.context).findViewById(R.id.paletteActivity);\n\n Snackbar snackbar = Snackbar.make(view, R.string.undoColorShift,\n Snackbar.LENGTH_LONG);\n\n snackbar.setAction(\"UNDO\", v -> undoChange());\n snackbar.show();\n }", "public static void showSnackBarLong(CoordinatorLayout coordinatorLayout, String string) {\n\n Snackbar.make(coordinatorLayout, string,Snackbar.LENGTH_LONG).show();\n\n }", "void showErrorSnackbar();", "public interface OnSnackBarActionListener {\n /**\n * On snack bar action clicked.\n *\n * @param uniqueId the unique id\n * @param view the mView\n */\n void onSnackBarActionClicked(int uniqueId, View view);\n}", "private void init_titlebar() {\n\t\tbackBtn = (Button) findViewById(R.id.titlebar_back);\n\t\ttitleTv = (TextView) findViewById(R.id.titlebar_title);\n\t\totherBtn = (Button) findViewById(R.id.titlebar_other);\n\n\t\tbackBtn.setOnClickListener(this);\n\t\ttitleTv.setText(R.string.WXYT);\n\t\totherBtn.setVisibility(View.GONE);\n\t\tprogressBar = (ProgressBar) findViewById(R.id.progressbar);\n\t\tprogressBar\n\t\t\t\t.setScrollBarStyle(android.R.attr.progressBarStyleHorizontal);\n\t}", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n findViewById(R.id.collapsing_toolbar);\n\n// collapsingToolbar.setTitle(pindah.getStringExtra(\"judul\"));\n\n AppBarLayout appBarLayout = findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(pindah.getStringExtra(\"judul\"));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void SnackShowTop(String message, View view) {\n Snackbar snack = Snackbar.make(view, message, Snackbar.LENGTH_LONG);\n View view_layout = snack.getView();\n FrameLayout.LayoutParams params = (FrameLayout.LayoutParams) view_layout.getLayoutParams();\n params.gravity = Gravity.TOP;\n view_layout.setLayoutParams(params);\n snack.show();\n }", "public String getSnackBarText() {\n return snackBar.getText();\n }", "@Override\n public void onFailure(@NonNull Call<Void> call, @NonNull Throwable t) {\n Snackbar.make(findViewById(R.id.activity_coordinator_layout), t.getLocalizedMessage(), Snackbar.LENGTH_INDEFINITE).show();\n }", "private void CreateToolBars(){\n toolBar = new ToolBar();\n btoolBar = new ToolBar();\n login=new Button(\"Login\");\n simulate=new Button(\"Simulate\");\n scoreBoardButton=new Button(\"ScoreBoard\");\n viewBracket= new Button(\"view Bracket\");\n clearButton=new Button(\"Clear\");\n resetButton=new Button(\"Reset\");\n finalizeButton=new Button(\"Finalize\");\n toolBar.getItems().addAll(\n createSpacer(),\n login,\n simulate,\n scoreBoardButton,\n viewBracket,\n createSpacer()\n );\n btoolBar.getItems().addAll(\n createSpacer(),\n clearButton,\n resetButton,\n finalizeButton,\n createSpacer()\n );\n }", "private void makeSnack() {\n\t\teating = true;\n\t\ttama.setLayoutX(200);\n\t\t\n\t\tsnack = new Sprite(3, 3, 22, 25, new Image(\"file:./res/images/snack.png\"), 1, 1000);\n\t\tsnack.setLayoutX(150);\n\t\tsnack.setLayoutY(150);\n\t\tsnack.setScaleX(0.3);\n\t\tsnack.setScaleY(0.3);\n\t\tgrid.getChildren().addAll(snack);\n\t\tPauseTransition pause = new PauseTransition(Duration.millis(1500));\n\t\tpause.setOnFinished(e -> {\n\t\t\tgrid.getChildren().remove(snack);\n\t\t\ttama.setLayoutX(190);\n\t\t\teating = false;\n\t\t\tmodel.getController().eatSnack();\n//\t\t\tif(!model.isHealthy()){\n//\t\t\t\tsetSickImg();\n//\t\t\t}\n\t\t});\n\t\tpause.play();\n\t\t\n\t}", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "@android.annotation.SuppressLint({\"Recycle\"})\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public android.view.View createView(android.content.Context r38) {\n /*\n r37 = this;\n r6 = r37\n r7 = r38\n r8 = 1\n r6.hasOwnBackground = r8\n boolean r0 = org.telegram.messenger.AndroidUtilities.isTablet()\n r9 = 0\n if (r0 == 0) goto L_0x0013\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar\n r0.setOccupyStatusBar(r9)\n L_0x0013:\n android.widget.FrameLayout r0 = new android.widget.FrameLayout\n r0.<init>(r7)\n r6.page1 = r0\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar\n org.telegram.ui.ActionBar.ActionBarMenu r0 = r0.createMenu()\n r1 = 2131165479(0x7var_, float:1.7945176E38)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r0.addItem((int) r9, (int) r1)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r0.setIsSearchField(r8)\n org.telegram.ui.ThemePreviewActivity$1 r1 = new org.telegram.ui.ThemePreviewActivity$1\n r1.<init>(r6)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r0.setActionBarMenuItemSearchListener(r1)\n r1 = 2131627500(0x7f0e0dec, float:1.8882266E38)\n java.lang.String r2 = \"Search\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.setSearchFieldHint(r1)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar\n org.telegram.ui.ActionBar.MenuDrawable r1 = new org.telegram.ui.ActionBar.MenuDrawable\n r1.<init>()\n r0.setBackButtonDrawable(r1)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar\n r0.setAddToContainer(r9)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar\n r1 = 2131627984(0x7f0e0fd0, float:1.8883248E38)\n java.lang.String r2 = \"ThemePreview\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.setTitle(r1)\n org.telegram.ui.ThemePreviewActivity$2 r0 = new org.telegram.ui.ThemePreviewActivity$2\n r0.<init>(r7)\n r6.page1 = r0\n java.lang.String r1 = \"windowBackgroundWhite\"\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r1)\n r0.setBackgroundColor(r1)\n android.widget.FrameLayout r0 = r6.page1\n org.telegram.ui.ActionBar.ActionBar r1 = r6.actionBar\n r2 = -1073741824(0xffffffffCLASSNAME, float:-2.0)\n r10 = -1\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r10, r2)\n r0.addView(r1, r2)\n org.telegram.ui.Components.RecyclerListView r0 = new org.telegram.ui.Components.RecyclerListView\n r0.<init>(r7)\n r6.listView = r0\n r0.setVerticalScrollBarEnabled(r8)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n r11 = 0\n r0.setItemAnimator(r11)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n r0.setLayoutAnimation(r11)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n androidx.recyclerview.widget.LinearLayoutManager r1 = new androidx.recyclerview.widget.LinearLayoutManager\n r1.<init>(r7, r8, r9)\n r0.setLayoutManager(r1)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n boolean r1 = org.telegram.messenger.LocaleController.isRTL\n r12 = 2\n if (r1 == 0) goto L_0x00a3\n r1 = 1\n goto L_0x00a4\n L_0x00a3:\n r1 = 2\n L_0x00a4:\n r0.setVerticalScrollbarPosition(r1)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n int r1 = r6.screenType\n if (r1 == 0) goto L_0x00b0\n r1 = 1094713344(0x41400000, float:12.0)\n goto L_0x00b1\n L_0x00b0:\n r1 = 0\n L_0x00b1:\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r1)\n r0.setPadding(r9, r9, r9, r1)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda24 r1 = org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda24.INSTANCE\n r0.setOnItemClickListener((org.telegram.ui.Components.RecyclerListView.OnItemClickListener) r1)\n android.widget.FrameLayout r0 = r6.page1\n org.telegram.ui.Components.RecyclerListView r1 = r6.listView\n r14 = 51\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r10, r10, r14)\n r0.addView(r1, r2)\n android.widget.ImageView r0 = new android.widget.ImageView\n r0.<init>(r7)\n r6.floatingButton = r0\n android.widget.ImageView$ScaleType r1 = android.widget.ImageView.ScaleType.CENTER\n r0.setScaleType(r1)\n r15 = 1113587712(0x42600000, float:56.0)\n int r0 = org.telegram.messenger.AndroidUtilities.dp(r15)\n java.lang.String r1 = \"chats_actionBackground\"\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r1)\n java.lang.String r2 = \"chats_actionPressedBackground\"\n int r2 = org.telegram.ui.ActionBar.Theme.getColor(r2)\n android.graphics.drawable.Drawable r0 = org.telegram.ui.ActionBar.Theme.createSimpleSelectorCircleDrawable(r0, r1, r2)\n int r1 = android.os.Build.VERSION.SDK_INT\n r2 = 21\n if (r1 >= r2) goto L_0x0120\n android.content.res.Resources r3 = r38.getResources()\n r4 = 2131165419(0x7var_eb, float:1.7945055E38)\n android.graphics.drawable.Drawable r3 = r3.getDrawable(r4)\n android.graphics.drawable.Drawable r3 = r3.mutate()\n android.graphics.PorterDuffColorFilter r4 = new android.graphics.PorterDuffColorFilter\n r5 = -16777216(0xfffffffffvar_, float:-1.7014118E38)\n android.graphics.PorterDuff$Mode r13 = android.graphics.PorterDuff.Mode.MULTIPLY\n r4.<init>(r5, r13)\n r3.setColorFilter(r4)\n org.telegram.ui.Components.CombinedDrawable r4 = new org.telegram.ui.Components.CombinedDrawable\n r4.<init>(r3, r0, r9, r9)\n int r0 = org.telegram.messenger.AndroidUtilities.dp(r15)\n int r3 = org.telegram.messenger.AndroidUtilities.dp(r15)\n r4.setIconSize(r0, r3)\n r0 = r4\n L_0x0120:\n android.widget.ImageView r3 = r6.floatingButton\n r3.setBackgroundDrawable(r0)\n android.widget.ImageView r0 = r6.floatingButton\n android.graphics.PorterDuffColorFilter r3 = new android.graphics.PorterDuffColorFilter\n java.lang.String r4 = \"chats_actionIcon\"\n int r4 = org.telegram.ui.ActionBar.Theme.getColor(r4)\n android.graphics.PorterDuff$Mode r5 = android.graphics.PorterDuff.Mode.MULTIPLY\n r3.<init>(r4, r5)\n r0.setColorFilter(r3)\n android.widget.ImageView r0 = r6.floatingButton\n r3 = 2131165418(0x7var_ea, float:1.7945053E38)\n r0.setImageResource(r3)\n r13 = 1082130432(0x40800000, float:4.0)\n if (r1 < r2) goto L_0x01a4\n android.animation.StateListAnimator r0 = new android.animation.StateListAnimator\n r0.<init>()\n int[] r3 = new int[r8]\n r4 = 16842919(0x10100a7, float:2.3694026E-38)\n r3[r9] = r4\n android.widget.ImageView r4 = r6.floatingButton\n android.util.Property r5 = android.view.View.TRANSLATION_Z\n float[] r15 = new float[r12]\n r18 = 1073741824(0x40000000, float:2.0)\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r18)\n float r10 = (float) r10\n r15[r9] = r10\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r13)\n float r10 = (float) r10\n r15[r8] = r10\n android.animation.ObjectAnimator r4 = android.animation.ObjectAnimator.ofFloat(r4, r5, r15)\n r14 = 200(0xc8, double:9.9E-322)\n android.animation.ObjectAnimator r4 = r4.setDuration(r14)\n r0.addState(r3, r4)\n int[] r3 = new int[r9]\n android.widget.ImageView r4 = r6.floatingButton\n float[] r14 = new float[r12]\n int r15 = org.telegram.messenger.AndroidUtilities.dp(r13)\n float r15 = (float) r15\n r14[r9] = r15\n r15 = 1073741824(0x40000000, float:2.0)\n int r15 = org.telegram.messenger.AndroidUtilities.dp(r15)\n float r15 = (float) r15\n r14[r8] = r15\n android.animation.ObjectAnimator r4 = android.animation.ObjectAnimator.ofFloat(r4, r5, r14)\n r14 = 200(0xc8, double:9.9E-322)\n android.animation.ObjectAnimator r4 = r4.setDuration(r14)\n r0.addState(r3, r4)\n android.widget.ImageView r3 = r6.floatingButton\n r3.setStateListAnimator(r0)\n android.widget.ImageView r0 = r6.floatingButton\n org.telegram.ui.ThemePreviewActivity$3 r3 = new org.telegram.ui.ThemePreviewActivity$3\n r3.<init>(r6)\n r0.setOutlineProvider(r3)\n L_0x01a4:\n android.widget.FrameLayout r0 = r6.page1\n android.widget.ImageView r3 = r6.floatingButton\n if (r1 < r2) goto L_0x01af\n r4 = 56\n r19 = 56\n goto L_0x01b3\n L_0x01af:\n r4 = 60\n r19 = 60\n L_0x01b3:\n if (r1 < r2) goto L_0x01b8\n r20 = 1113587712(0x42600000, float:56.0)\n goto L_0x01bc\n L_0x01b8:\n r1 = 1114636288(0x42700000, float:60.0)\n r20 = 1114636288(0x42700000, float:60.0)\n L_0x01bc:\n boolean r1 = org.telegram.messenger.LocaleController.isRTL\n r14 = 3\n if (r1 == 0) goto L_0x01c3\n r2 = 3\n goto L_0x01c4\n L_0x01c3:\n r2 = 5\n L_0x01c4:\n r21 = r2 | 80\n r15 = 1096810496(0x41600000, float:14.0)\n if (r1 == 0) goto L_0x01cd\n r22 = 1096810496(0x41600000, float:14.0)\n goto L_0x01cf\n L_0x01cd:\n r22 = 0\n L_0x01cf:\n r23 = 0\n if (r1 == 0) goto L_0x01d6\n r24 = 0\n goto L_0x01d8\n L_0x01d6:\n r24 = 1096810496(0x41600000, float:14.0)\n L_0x01d8:\n r25 = 1096810496(0x41600000, float:14.0)\n android.widget.FrameLayout$LayoutParams r1 = org.telegram.ui.Components.LayoutHelper.createFrame(r19, r20, r21, r22, r23, r24, r25)\n r0.addView(r3, r1)\n org.telegram.ui.ThemePreviewActivity$DialogsAdapter r0 = new org.telegram.ui.ThemePreviewActivity$DialogsAdapter\n r0.<init>(r7)\n r6.dialogsAdapter = r0\n org.telegram.ui.Components.RecyclerListView r1 = r6.listView\n r1.setAdapter(r0)\n org.telegram.ui.ThemePreviewActivity$4 r0 = new org.telegram.ui.ThemePreviewActivity$4\n r0.<init>(r7)\n r6.page2 = r0\n org.telegram.ui.ThemePreviewActivity$MessagesAdapter r0 = new org.telegram.ui.ThemePreviewActivity$MessagesAdapter\n r0.<init>(r6, r7)\n r6.messagesAdapter = r0\n org.telegram.ui.ActionBar.ActionBar r0 = r37.createActionBar(r38)\n r6.actionBar2 = r0\n boolean r0 = org.telegram.messenger.AndroidUtilities.isTablet()\n if (r0 == 0) goto L_0x020c\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n r0.setOccupyStatusBar(r9)\n L_0x020c:\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n org.telegram.ui.ActionBar.BackDrawable r1 = new org.telegram.ui.ActionBar.BackDrawable\n r1.<init>(r9)\n r0.setBackButtonDrawable(r1)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n org.telegram.ui.ThemePreviewActivity$5 r1 = new org.telegram.ui.ThemePreviewActivity$5\n r1.<init>()\n r0.setActionBarMenuOnItemClick(r1)\n org.telegram.ui.ThemePreviewActivity$6 r0 = new org.telegram.ui.ThemePreviewActivity$6\n r0.<init>(r7)\n r6.backgroundImage = r0\n android.widget.FrameLayout r1 = r6.page2\n r19 = -1\n r20 = -1082130432(0xffffffffbvar_, float:-1.0)\n r21 = 51\n r22 = 0\n r23 = 0\n r24 = 0\n r25 = 1111490560(0x42400000, float:48.0)\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r19, r20, r21, r22, r23, r24, r25)\n r1.addView(r0, r2)\n int r0 = r6.screenType\n if (r0 != r12) goto L_0x0250\n org.telegram.ui.Components.BackupImageView r0 = r6.backgroundImage\n org.telegram.messenger.ImageReceiver r0 = r0.getImageReceiver()\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda19 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda19\n r1.<init>(r6)\n r0.setDelegate(r1)\n L_0x0250:\n org.telegram.ui.ThemePreviewActivity$MessagesAdapter r0 = r6.messagesAdapter\n boolean r0 = r0.showSecretMessages\n r5 = 4\n r18 = 1092616192(0x41200000, float:10.0)\n java.lang.String r19 = \"fonts/rmedium.ttf\"\n if (r0 == 0) goto L_0x0273\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n java.lang.String r1 = \"Telegram Beta Chat\"\n r0.setTitle(r1)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n r1 = 505(0x1f9, float:7.08E-43)\n java.lang.String r2 = \"Members\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.formatPluralString(r2, r1)\n r0.setSubtitle(r1)\n goto L_0x042b\n L_0x0273:\n int r0 = r6.screenType\n if (r0 != r12) goto L_0x02ba\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n r1 = 2131624542(0x7f0e025e, float:1.8876267E38)\n java.lang.String r2 = \"BackgroundPreview\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.setTitle(r1)\n boolean r0 = org.telegram.messenger.BuildVars.DEBUG_PRIVATE_VERSION\n if (r0 == 0) goto L_0x0293\n org.telegram.ui.ActionBar.Theme$ThemeInfo r0 = org.telegram.ui.ActionBar.Theme.getActiveTheme()\n org.telegram.ui.ActionBar.Theme$ThemeAccent r0 = r0.getAccent(r9)\n if (r0 != 0) goto L_0x02ab\n L_0x0293:\n java.lang.Object r0 = r6.currentWallpaper\n boolean r1 = r0 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r1 == 0) goto L_0x02a5\n org.telegram.ui.WallpapersListActivity$ColorWallpaper r0 = (org.telegram.ui.WallpapersListActivity.ColorWallpaper) r0\n java.lang.String r0 = r0.slug\n java.lang.String r1 = \"d\"\n boolean r0 = r1.equals(r0)\n if (r0 == 0) goto L_0x02ab\n L_0x02a5:\n java.lang.Object r0 = r6.currentWallpaper\n boolean r0 = r0 instanceof org.telegram.tgnet.TLRPC$TL_wallPaper\n if (r0 == 0) goto L_0x042b\n L_0x02ab:\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n org.telegram.ui.ActionBar.ActionBarMenu r0 = r0.createMenu()\n r1 = 5\n r2 = 2131165839(0x7var_f, float:1.7945906E38)\n r0.addItem((int) r1, (int) r2)\n goto L_0x042b\n L_0x02ba:\n if (r0 != r8) goto L_0x03e4\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n org.telegram.ui.ActionBar.ActionBarMenu r3 = r0.createMenu()\n r0 = 2131627478(0x7f0e0dd6, float:1.8882222E38)\n java.lang.String r1 = \"Save\"\n java.lang.String r0 = org.telegram.messenger.LocaleController.getString(r1, r0)\n java.lang.String r0 = r0.toUpperCase()\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r3.addItem((int) r5, (java.lang.CharSequence) r0)\n r6.saveItem = r0\n org.telegram.ui.ThemePreviewActivity$7 r4 = new org.telegram.ui.ThemePreviewActivity$7\n r20 = 0\n r21 = 0\n r0 = r4\n r1 = r37\n r2 = r38\n r10 = r4\n r4 = r20\n r5 = r21\n r0.<init>(r2, r3, r4, r5)\n r6.dropDownContainer = r10\n r10.setSubMenuOpenSide(r8)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n r1 = 2131624983(0x7f0e0417, float:1.8877161E38)\n java.lang.String r2 = \"ColorPickerBackground\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.addSubItem(r12, r1)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n r1 = 2131624984(0x7f0e0418, float:1.8877163E38)\n java.lang.String r2 = \"ColorPickerMainColor\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.addSubItem(r8, r1)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n r1 = 2131624985(0x7f0e0419, float:1.8877165E38)\n java.lang.String r2 = \"ColorPickerMyMessages\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.addSubItem(r14, r1)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n r0.setAllowCloseAnimation(r9)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n r0.setForceSmoothKeyboard(r8)\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n org.telegram.ui.ActionBar.ActionBarMenuItem r1 = r6.dropDownContainer\n r26 = -2\n r27 = -1082130432(0xffffffffbvar_, float:-1.0)\n r28 = 51\n boolean r2 = org.telegram.messenger.AndroidUtilities.isTablet()\n if (r2 == 0) goto L_0x0336\n r2 = 1115684864(0x42800000, float:64.0)\n r29 = 1115684864(0x42800000, float:64.0)\n goto L_0x0338\n L_0x0336:\n r29 = 1113587712(0x42600000, float:56.0)\n L_0x0338:\n r30 = 0\n r31 = 1109393408(0x42200000, float:40.0)\n r32 = 0\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r26, r27, r28, r29, r30, r31, r32)\n r0.addView(r1, r2)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda8 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda8\n r1.<init>(r6)\n r0.setOnClickListener(r1)\n android.widget.TextView r0 = new android.widget.TextView\n r0.<init>(r7)\n r6.dropDown = r0\n r0.setImportantForAccessibility(r12)\n android.widget.TextView r0 = r6.dropDown\n r0.setGravity(r14)\n android.widget.TextView r0 = r6.dropDown\n r0.setSingleLine(r8)\n android.widget.TextView r0 = r6.dropDown\n r0.setLines(r8)\n android.widget.TextView r0 = r6.dropDown\n r0.setMaxLines(r8)\n android.widget.TextView r0 = r6.dropDown\n android.text.TextUtils$TruncateAt r1 = android.text.TextUtils.TruncateAt.END\n r0.setEllipsize(r1)\n android.widget.TextView r0 = r6.dropDown\n java.lang.String r1 = \"actionBarDefaultTitle\"\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r1)\n r0.setTextColor(r1)\n android.widget.TextView r0 = r6.dropDown\n android.graphics.Typeface r1 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r0.setTypeface(r1)\n android.widget.TextView r0 = r6.dropDown\n r1 = 2131624984(0x7f0e0418, float:1.8877163E38)\n java.lang.String r2 = \"ColorPickerMainColor\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n r0.setText(r1)\n android.content.res.Resources r0 = r38.getResources()\n r1 = 2131165487(0x7var_f, float:1.7945193E38)\n android.graphics.drawable.Drawable r0 = r0.getDrawable(r1)\n android.graphics.drawable.Drawable r0 = r0.mutate()\n android.graphics.PorterDuffColorFilter r1 = new android.graphics.PorterDuffColorFilter\n java.lang.String r2 = \"actionBarDefaultTitle\"\n int r2 = org.telegram.ui.ActionBar.Theme.getColor(r2)\n android.graphics.PorterDuff$Mode r3 = android.graphics.PorterDuff.Mode.MULTIPLY\n r1.<init>(r2, r3)\n r0.setColorFilter(r1)\n android.widget.TextView r1 = r6.dropDown\n r1.setCompoundDrawablesWithIntrinsicBounds(r11, r11, r0, r11)\n android.widget.TextView r0 = r6.dropDown\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r13)\n r0.setCompoundDrawablePadding(r1)\n android.widget.TextView r0 = r6.dropDown\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r18)\n r0.setPadding(r9, r9, r1, r9)\n org.telegram.ui.ActionBar.ActionBarMenuItem r0 = r6.dropDownContainer\n android.widget.TextView r1 = r6.dropDown\n r26 = -2\n r27 = -1073741824(0xffffffffCLASSNAME, float:-2.0)\n r28 = 16\n r29 = 1098907648(0x41800000, float:16.0)\n r31 = 0\n r32 = 1065353216(0x3var_, float:1.0)\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r26, r27, r28, r29, r30, r31, r32)\n r0.addView(r1, r2)\n goto L_0x042b\n L_0x03e4:\n org.telegram.ui.ActionBar.Theme$ThemeInfo r0 = r6.applyingTheme\n org.telegram.tgnet.TLRPC$TL_theme r1 = r0.info\n if (r1 == 0) goto L_0x03ed\n java.lang.String r0 = r1.title\n goto L_0x03f1\n L_0x03ed:\n java.lang.String r0 = r0.getName()\n L_0x03f1:\n java.lang.String r1 = \".attheme\"\n int r1 = r0.lastIndexOf(r1)\n if (r1 < 0) goto L_0x03fd\n java.lang.String r0 = r0.substring(r9, r1)\n L_0x03fd:\n org.telegram.ui.ActionBar.ActionBar r1 = r6.actionBar2\n r1.setTitle(r0)\n org.telegram.ui.ActionBar.Theme$ThemeInfo r0 = r6.applyingTheme\n org.telegram.tgnet.TLRPC$TL_theme r0 = r0.info\n if (r0 == 0) goto L_0x0418\n int r0 = r0.installs_count\n if (r0 <= 0) goto L_0x0418\n org.telegram.ui.ActionBar.ActionBar r1 = r6.actionBar2\n java.lang.String r2 = \"ThemeInstallCount\"\n java.lang.String r0 = org.telegram.messenger.LocaleController.formatPluralString(r2, r0)\n r1.setSubtitle(r0)\n goto L_0x042b\n L_0x0418:\n org.telegram.ui.ActionBar.ActionBar r0 = r6.actionBar2\n long r1 = java.lang.System.currentTimeMillis()\n r3 = 1000(0x3e8, double:4.94E-321)\n long r1 = r1 / r3\n r3 = 3600(0xe10, double:1.7786E-320)\n long r1 = r1 - r3\n java.lang.String r1 = org.telegram.messenger.LocaleController.formatDateOnline(r1)\n r0.setSubtitle(r1)\n L_0x042b:\n org.telegram.ui.ThemePreviewActivity$8 r0 = new org.telegram.ui.ThemePreviewActivity$8\n r0.<init>(r7)\n r6.listView2 = r0\n org.telegram.ui.ThemePreviewActivity$9 r0 = new org.telegram.ui.ThemePreviewActivity$9\n r0.<init>()\n r0.setDelayAnimations(r9)\n org.telegram.ui.Components.RecyclerListView r1 = r6.listView2\n r1.setItemAnimator(r0)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n r0.setVerticalScrollBarEnabled(r8)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n r0.setOverScrollMode(r12)\n int r0 = r6.screenType\n if (r0 != r12) goto L_0x045d\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r13)\n r2 = 1112539136(0x42500000, float:52.0)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r0.setPadding(r9, r1, r9, r2)\n goto L_0x047c\n L_0x045d:\n if (r0 != r8) goto L_0x046f\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r13)\n r2 = 1098907648(0x41800000, float:16.0)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r0.setPadding(r9, r1, r9, r2)\n goto L_0x047c\n L_0x046f:\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r13)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r13)\n r0.setPadding(r9, r1, r9, r2)\n L_0x047c:\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n r0.setClipToPadding(r9)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n androidx.recyclerview.widget.LinearLayoutManager r1 = new androidx.recyclerview.widget.LinearLayoutManager\n r1.<init>(r7, r8, r8)\n r0.setLayoutManager(r1)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n boolean r1 = org.telegram.messenger.LocaleController.isRTL\n if (r1 == 0) goto L_0x0493\n r1 = 1\n goto L_0x0494\n L_0x0493:\n r1 = 2\n L_0x0494:\n r0.setVerticalScrollbarPosition(r1)\n int r0 = r6.screenType\n if (r0 != r8) goto L_0x04c1\n android.widget.FrameLayout r0 = r6.page2\n org.telegram.ui.Components.RecyclerListView r1 = r6.listView2\n r26 = -1\n r27 = -1082130432(0xffffffffbvar_, float:-1.0)\n r28 = 51\n r29 = 0\n r30 = 0\n r31 = 0\n r32 = 1133019136(0x43888000, float:273.0)\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r26, r27, r28, r29, r30, r31, r32)\n r0.addView(r1, r2)\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda25 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda25\n r1.<init>(r6)\n r0.setOnItemClickListener((org.telegram.ui.Components.RecyclerListView.OnItemClickListenerExtended) r1)\n r3 = -1\n goto L_0x04cf\n L_0x04c1:\n android.widget.FrameLayout r0 = r6.page2\n org.telegram.ui.Components.RecyclerListView r1 = r6.listView2\n r2 = 51\n r3 = -1\n android.widget.FrameLayout$LayoutParams r4 = org.telegram.ui.Components.LayoutHelper.createFrame(r3, r3, r2)\n r0.addView(r1, r4)\n L_0x04cf:\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n org.telegram.ui.ThemePreviewActivity$10 r1 = new org.telegram.ui.ThemePreviewActivity$10\n r1.<init>()\n r0.setOnScrollListener(r1)\n android.widget.FrameLayout r0 = r6.page2\n org.telegram.ui.ActionBar.ActionBar r1 = r6.actionBar2\n r2 = -1073741824(0xffffffffCLASSNAME, float:-2.0)\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r3, r2)\n r0.addView(r1, r2)\n org.telegram.ui.Components.WallpaperParallaxEffect r0 = new org.telegram.ui.Components.WallpaperParallaxEffect\n r0.<init>(r7)\n r6.parallaxEffect = r0\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda26 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda26\n r1.<init>(r6)\n r0.setCallback(r1)\n int r0 = r6.screenType\n java.lang.String r3 = \"chat_fieldOverlayText\"\n r4 = 17\n r5 = -2\n if (r0 == r8) goto L_0x0506\n if (r0 != r12) goto L_0x0501\n goto L_0x0506\n L_0x0501:\n r28 = r3\n r4 = 0\n goto L_0x0CLASSNAME\n L_0x0506:\n org.telegram.ui.Components.RadialProgress2 r0 = new org.telegram.ui.Components.RadialProgress2\n org.telegram.ui.Components.BackupImageView r13 = r6.backgroundImage\n r0.<init>(r13)\n r6.radialProgress = r0\n java.lang.String r13 = \"chat_serviceBackground\"\n java.lang.String r10 = \"chat_serviceBackground\"\n java.lang.String r11 = \"chat_serviceText\"\n java.lang.String r1 = \"chat_serviceText\"\n r0.setColors((java.lang.String) r13, (java.lang.String) r10, (java.lang.String) r11, (java.lang.String) r1)\n int r0 = r6.screenType\n if (r0 != r12) goto L_0x0585\n org.telegram.ui.ThemePreviewActivity$11 r0 = new org.telegram.ui.ThemePreviewActivity$11\n r0.<init>(r6, r7)\n r6.bottomOverlayChat = r0\n r0.setWillNotDraw(r9)\n android.widget.FrameLayout r0 = r6.bottomOverlayChat\n r1 = 1077936128(0x40400000, float:3.0)\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r1)\n r0.setPadding(r9, r1, r9, r9)\n android.widget.FrameLayout r0 = r6.page2\n android.widget.FrameLayout r1 = r6.bottomOverlayChat\n r10 = 80\n r11 = 51\n r13 = -1\n android.widget.FrameLayout$LayoutParams r10 = org.telegram.ui.Components.LayoutHelper.createFrame(r13, r11, r10)\n r11 = r10\n r0.addView(r1, r11)\n android.widget.FrameLayout r0 = r6.bottomOverlayChat\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda7 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda7\n r1.<init>(r6)\n r0.setOnClickListener(r1)\n android.widget.TextView r0 = new android.widget.TextView\n r0.<init>(r7)\n r6.bottomOverlayChatText = r0\n r1 = 1097859072(0x41700000, float:15.0)\n r0.setTextSize(r8, r1)\n android.widget.TextView r0 = r6.bottomOverlayChatText\n android.graphics.Typeface r1 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r0.setTypeface(r1)\n android.widget.TextView r0 = r6.bottomOverlayChatText\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r3)\n r0.setTextColor(r1)\n android.widget.TextView r0 = r6.bottomOverlayChatText\n r1 = 2131627638(0x7f0e0e76, float:1.8882546E38)\n java.lang.String r11 = \"SetBackground\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r11, r1)\n r0.setText(r1)\n android.widget.FrameLayout r0 = r6.bottomOverlayChat\n android.widget.TextView r1 = r6.bottomOverlayChatText\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r5, r4)\n r0.addView(r1, r11)\n L_0x0585:\n android.graphics.Rect r0 = new android.graphics.Rect\n r0.<init>()\n android.content.res.Resources r1 = r38.getResources()\n r11 = 2131166052(0x7var_, float:1.7946338E38)\n android.graphics.drawable.Drawable r1 = r1.getDrawable(r11)\n android.graphics.drawable.Drawable r1 = r1.mutate()\n r6.sheetDrawable = r1\n r1.getPadding(r0)\n android.graphics.drawable.Drawable r1 = r6.sheetDrawable\n android.graphics.PorterDuffColorFilter r11 = new android.graphics.PorterDuffColorFilter\n java.lang.String r13 = \"windowBackgroundWhite\"\n int r13 = org.telegram.ui.ActionBar.Theme.getColor(r13)\n android.graphics.PorterDuff$Mode r10 = android.graphics.PorterDuff.Mode.MULTIPLY\n r11.<init>(r13, r10)\n r1.setColorFilter(r11)\n android.text.TextPaint r1 = new android.text.TextPaint\n r1.<init>(r8)\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r15)\n float r10 = (float) r10\n r1.setTextSize(r10)\n android.graphics.Typeface r10 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r1.setTypeface(r10)\n int r10 = r6.screenType\n if (r10 == r8) goto L_0x05e2\n java.lang.Object r10 = r6.currentWallpaper\n boolean r11 = r10 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r11 == 0) goto L_0x05cf\n goto L_0x05e2\n L_0x05cf:\n boolean r11 = r10 instanceof org.telegram.ui.WallpapersListActivity.FileWallpaper\n if (r11 == 0) goto L_0x05e0\n org.telegram.ui.WallpapersListActivity$FileWallpaper r10 = (org.telegram.ui.WallpapersListActivity.FileWallpaper) r10\n java.lang.String r10 = r10.slug\n java.lang.String r11 = \"t\"\n boolean r10 = r11.equals(r10)\n if (r10 == 0) goto L_0x05e0\n goto L_0x05f4\n L_0x05e0:\n r10 = 2\n goto L_0x05f7\n L_0x05e2:\n java.lang.Object r10 = r6.currentWallpaper\n boolean r11 = r10 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r11 == 0) goto L_0x05f6\n org.telegram.ui.WallpapersListActivity$ColorWallpaper r10 = (org.telegram.ui.WallpapersListActivity.ColorWallpaper) r10\n java.lang.String r10 = r10.slug\n java.lang.String r11 = \"d\"\n boolean r10 = r11.equals(r10)\n if (r10 == 0) goto L_0x05f6\n L_0x05f4:\n r10 = 0\n goto L_0x05f7\n L_0x05f6:\n r10 = 3\n L_0x05f7:\n java.lang.String[] r11 = new java.lang.String[r10]\n int[] r13 = new int[r10]\n org.telegram.ui.Components.WallpaperCheckBoxView[] r15 = new org.telegram.ui.Components.WallpaperCheckBoxView[r10]\n r6.backgroundCheckBoxView = r15\n if (r10 == 0) goto L_0x06f4\n android.widget.FrameLayout r15 = new android.widget.FrameLayout\n r15.<init>(r7)\n r6.backgroundButtonsContainer = r15\n int r15 = r6.screenType\n if (r15 == r8) goto L_0x062a\n java.lang.Object r15 = r6.currentWallpaper\n boolean r15 = r15 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r15 == 0) goto L_0x0613\n goto L_0x062a\n L_0x0613:\n r15 = 2131624530(0x7f0e0252, float:1.8876242E38)\n java.lang.String r14 = \"BackgroundBlurred\"\n java.lang.String r14 = org.telegram.messenger.LocaleController.getString(r14, r15)\n r11[r9] = r14\n r14 = 2131624540(0x7f0e025c, float:1.8876263E38)\n java.lang.String r15 = \"BackgroundMotion\"\n java.lang.String r14 = org.telegram.messenger.LocaleController.getString(r15, r14)\n r11[r8] = r14\n goto L_0x064b\n L_0x062a:\n r14 = 2131624537(0x7f0e0259, float:1.8876257E38)\n java.lang.String r15 = \"BackgroundColors\"\n java.lang.String r14 = org.telegram.messenger.LocaleController.getString(r15, r14)\n r11[r9] = r14\n r14 = 2131624541(0x7f0e025d, float:1.8876265E38)\n java.lang.String r15 = \"BackgroundPattern\"\n java.lang.String r14 = org.telegram.messenger.LocaleController.getString(r15, r14)\n r11[r8] = r14\n r14 = 2131624540(0x7f0e025c, float:1.8876263E38)\n java.lang.String r15 = \"BackgroundMotion\"\n java.lang.String r14 = org.telegram.messenger.LocaleController.getString(r15, r14)\n r11[r12] = r14\n L_0x064b:\n r14 = 0\n r15 = 0\n L_0x064d:\n if (r14 >= r10) goto L_0x066b\n r12 = r11[r14]\n float r12 = r1.measureText(r12)\n r28 = r3\n double r2 = (double) r12\n double r2 = java.lang.Math.ceil(r2)\n int r2 = (int) r2\n r13[r14] = r2\n r2 = r13[r14]\n int r15 = java.lang.Math.max(r15, r2)\n int r14 = r14 + 1\n r3 = r28\n r12 = 2\n goto L_0x064d\n L_0x066b:\n r28 = r3\n org.telegram.ui.ThemePreviewActivity$12 r2 = new org.telegram.ui.ThemePreviewActivity$12\n r2.<init>(r7)\n r6.backgroundPlayAnimationView = r2\n r2.setWillNotDraw(r9)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n int r3 = r6.backgroundGradientColor1\n if (r3 == 0) goto L_0x067f\n r3 = 0\n goto L_0x0680\n L_0x067f:\n r3 = 4\n L_0x0680:\n r2.setVisibility(r3)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n int r3 = r6.backgroundGradientColor1\n if (r3 == 0) goto L_0x068c\n r3 = 1065353216(0x3var_, float:1.0)\n goto L_0x068f\n L_0x068c:\n r3 = 1036831949(0x3dcccccd, float:0.1)\n L_0x068f:\n r2.setScaleX(r3)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n int r3 = r6.backgroundGradientColor1\n if (r3 == 0) goto L_0x069b\n r3 = 1065353216(0x3var_, float:1.0)\n goto L_0x069e\n L_0x069b:\n r3 = 1036831949(0x3dcccccd, float:0.1)\n L_0x069e:\n r2.setScaleY(r3)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n int r3 = r6.backgroundGradientColor1\n if (r3 == 0) goto L_0x06aa\n r3 = 1065353216(0x3var_, float:1.0)\n goto L_0x06ab\n L_0x06aa:\n r3 = 0\n L_0x06ab:\n r2.setAlpha(r3)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n int r3 = r6.backgroundGradientColor1\n if (r3 == 0) goto L_0x06b9\n java.lang.Integer r3 = java.lang.Integer.valueOf(r8)\n goto L_0x06ba\n L_0x06b9:\n r3 = 0\n L_0x06ba:\n r2.setTag(r3)\n android.widget.FrameLayout r2 = r6.backgroundButtonsContainer\n android.widget.FrameLayout r3 = r6.backgroundPlayAnimationView\n r12 = 48\n android.widget.FrameLayout$LayoutParams r14 = org.telegram.ui.Components.LayoutHelper.createFrame(r12, r12, r4)\n r2.addView(r3, r14)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n org.telegram.ui.ThemePreviewActivity$13 r3 = new org.telegram.ui.ThemePreviewActivity$13\n r3.<init>()\n r2.setOnClickListener(r3)\n android.widget.ImageView r2 = new android.widget.ImageView\n r2.<init>(r7)\n r6.backgroundPlayAnimationImageView = r2\n android.widget.ImageView$ScaleType r3 = android.widget.ImageView.ScaleType.CENTER\n r2.setScaleType(r3)\n android.widget.ImageView r2 = r6.backgroundPlayAnimationImageView\n r3 = 2131165280(0x7var_, float:1.7944773E38)\n r2.setImageResource(r3)\n android.widget.FrameLayout r2 = r6.backgroundPlayAnimationView\n android.widget.ImageView r3 = r6.backgroundPlayAnimationImageView\n android.widget.FrameLayout$LayoutParams r12 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r5, r4)\n r2.addView(r3, r12)\n goto L_0x06f7\n L_0x06f4:\n r28 = r3\n r15 = 0\n L_0x06f7:\n r2 = 0\n L_0x06f8:\n if (r2 >= r10) goto L_0x07e1\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n org.telegram.ui.Components.WallpaperCheckBoxView r12 = new org.telegram.ui.Components.WallpaperCheckBoxView\n int r14 = r6.screenType\n if (r14 == r8) goto L_0x0708\n java.lang.Object r14 = r6.currentWallpaper\n boolean r14 = r14 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r14 == 0) goto L_0x070a\n L_0x0708:\n if (r2 == 0) goto L_0x070c\n L_0x070a:\n r14 = 1\n goto L_0x070d\n L_0x070c:\n r14 = 0\n L_0x070d:\n org.telegram.ui.Components.BackupImageView r4 = r6.backgroundImage\n r12.<init>(r7, r14, r4)\n r3[r2] = r12\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n int r4 = r6.backgroundColor\n r3.setBackgroundColor(r4)\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n r4 = r11[r2]\n r12 = r13[r2]\n r3.setText(r4, r12, r15)\n int r3 = r6.screenType\n if (r3 == r8) goto L_0x0742\n java.lang.Object r3 = r6.currentWallpaper\n boolean r3 = r3 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r3 == 0) goto L_0x0733\n goto L_0x0742\n L_0x0733:\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n if (r2 != 0) goto L_0x073c\n boolean r4 = r6.isBlurred\n goto L_0x073e\n L_0x073c:\n boolean r4 = r6.isMotion\n L_0x073e:\n r3.setChecked(r4, r9)\n goto L_0x076c\n L_0x0742:\n if (r2 != r8) goto L_0x0760\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n org.telegram.tgnet.TLRPC$TL_wallPaper r4 = r6.selectedPattern\n if (r4 != 0) goto L_0x075b\n org.telegram.ui.ActionBar.Theme$ThemeAccent r4 = r6.accent\n if (r4 == 0) goto L_0x0759\n java.lang.String r4 = r4.patternSlug\n boolean r4 = android.text.TextUtils.isEmpty(r4)\n if (r4 != 0) goto L_0x0759\n goto L_0x075b\n L_0x0759:\n r4 = 0\n goto L_0x075c\n L_0x075b:\n r4 = 1\n L_0x075c:\n r3.setChecked(r4, r9)\n goto L_0x076c\n L_0x0760:\n r3 = 2\n if (r2 != r3) goto L_0x076c\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n boolean r4 = r6.isMotion\n r3.setChecked(r4, r9)\n L_0x076c:\n r3 = 1113587712(0x42600000, float:56.0)\n int r4 = org.telegram.messenger.AndroidUtilities.dp(r3)\n int r4 = r4 + r15\n android.widget.FrameLayout$LayoutParams r3 = new android.widget.FrameLayout$LayoutParams\n r3.<init>(r4, r5)\n r12 = 17\n r3.gravity = r12\n r12 = 3\n if (r10 != r12) goto L_0x0799\n if (r2 == 0) goto L_0x078f\n r14 = 2\n if (r2 != r14) goto L_0x0785\n goto L_0x078f\n L_0x0785:\n int r4 = r4 / 2\n int r14 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r4 = r4 + r14\n r3.rightMargin = r4\n goto L_0x07ae\n L_0x078f:\n int r4 = r4 / 2\n int r14 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r4 = r4 + r14\n r3.leftMargin = r4\n goto L_0x07ae\n L_0x0799:\n if (r2 != r8) goto L_0x07a5\n int r4 = r4 / 2\n int r14 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r4 = r4 + r14\n r3.leftMargin = r4\n goto L_0x07ae\n L_0x07a5:\n int r4 = r4 / 2\n int r14 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r4 = r4 + r14\n r3.rightMargin = r4\n L_0x07ae:\n android.widget.FrameLayout r4 = r6.backgroundButtonsContainer\n org.telegram.ui.Components.WallpaperCheckBoxView[] r14 = r6.backgroundCheckBoxView\n r14 = r14[r2]\n r4.addView(r14, r3)\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r4 = r3[r2]\n r3 = r3[r2]\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda11 r14 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda11\n r14.<init>(r6, r2, r4)\n r3.setOnClickListener(r14)\n r3 = 2\n if (r2 != r3) goto L_0x07d9\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n r4 = 0\n r3.setAlpha(r4)\n org.telegram.ui.Components.WallpaperCheckBoxView[] r3 = r6.backgroundCheckBoxView\n r3 = r3[r2]\n r14 = 4\n r3.setVisibility(r14)\n goto L_0x07db\n L_0x07d9:\n r4 = 0\n r14 = 4\n L_0x07db:\n int r2 = r2 + 1\n r4 = 17\n goto L_0x06f8\n L_0x07e1:\n r4 = 0\n r14 = 4\n int r2 = r6.screenType\n if (r2 != r8) goto L_0x0917\n r2 = 2\n java.lang.String[] r3 = new java.lang.String[r2]\n int[] r10 = new int[r2]\n org.telegram.ui.Components.WallpaperCheckBoxView[] r11 = new org.telegram.ui.Components.WallpaperCheckBoxView[r2]\n r6.messagesCheckBoxView = r11\n android.widget.FrameLayout r2 = new android.widget.FrameLayout\n r2.<init>(r7)\n r6.messagesButtonsContainer = r2\n r2 = 2131624528(0x7f0e0250, float:1.8876238E38)\n java.lang.String r11 = \"BackgroundAnimate\"\n java.lang.String r2 = org.telegram.messenger.LocaleController.getString(r11, r2)\n r3[r9] = r2\n r2 = 2131624537(0x7f0e0259, float:1.8876257E38)\n java.lang.String r11 = \"BackgroundColors\"\n java.lang.String r2 = org.telegram.messenger.LocaleController.getString(r11, r2)\n r3[r8] = r2\n r2 = 0\n r11 = 0\n L_0x080f:\n r12 = 2\n if (r2 >= r12) goto L_0x0829\n r12 = r3[r2]\n float r12 = r1.measureText(r12)\n double r12 = (double) r12\n double r12 = java.lang.Math.ceil(r12)\n int r12 = (int) r12\n r10[r2] = r12\n r12 = r10[r2]\n int r11 = java.lang.Math.max(r11, r12)\n int r2 = r2 + 1\n goto L_0x080f\n L_0x0829:\n org.telegram.ui.ThemePreviewActivity$14 r1 = new org.telegram.ui.ThemePreviewActivity$14\n r1.<init>(r7)\n r6.messagesPlayAnimationView = r1\n r1.setWillNotDraw(r9)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.myMessagesGradientAccentColor1\n if (r2 == 0) goto L_0x083d\n r2 = 0\n goto L_0x083e\n L_0x083d:\n r2 = 4\n L_0x083e:\n r1.setVisibility(r2)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.myMessagesGradientAccentColor1\n if (r2 == 0) goto L_0x084c\n r2 = 1065353216(0x3var_, float:1.0)\n goto L_0x084f\n L_0x084c:\n r2 = 1036831949(0x3dcccccd, float:0.1)\n L_0x084f:\n r1.setScaleX(r2)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.myMessagesGradientAccentColor1\n if (r2 == 0) goto L_0x085d\n r2 = 1065353216(0x3var_, float:1.0)\n goto L_0x0860\n L_0x085d:\n r2 = 1036831949(0x3dcccccd, float:0.1)\n L_0x0860:\n r1.setScaleY(r2)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.myMessagesGradientAccentColor1\n if (r2 == 0) goto L_0x086e\n r15 = 1065353216(0x3var_, float:1.0)\n goto L_0x086f\n L_0x086e:\n r15 = 0\n L_0x086f:\n r1.setAlpha(r15)\n android.widget.FrameLayout r1 = r6.messagesButtonsContainer\n android.widget.FrameLayout r2 = r6.messagesPlayAnimationView\n r12 = 48\n r13 = 17\n android.widget.FrameLayout$LayoutParams r15 = org.telegram.ui.Components.LayoutHelper.createFrame(r12, r12, r13)\n r1.addView(r2, r15)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n org.telegram.ui.ThemePreviewActivity$15 r2 = new org.telegram.ui.ThemePreviewActivity$15\n r2.<init>()\n r1.setOnClickListener(r2)\n android.widget.ImageView r1 = new android.widget.ImageView\n r1.<init>(r7)\n r6.messagesPlayAnimationImageView = r1\n android.widget.ImageView$ScaleType r2 = android.widget.ImageView.ScaleType.CENTER\n r1.setScaleType(r2)\n android.widget.ImageView r1 = r6.messagesPlayAnimationImageView\n r2 = 2131165280(0x7var_, float:1.7944773E38)\n r1.setImageResource(r2)\n android.widget.FrameLayout r1 = r6.messagesPlayAnimationView\n android.widget.ImageView r2 = r6.messagesPlayAnimationImageView\n r12 = 17\n android.widget.FrameLayout$LayoutParams r13 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r5, r12)\n r1.addView(r2, r13)\n r1 = 0\n L_0x08ad:\n r2 = 2\n if (r1 >= r2) goto L_0x0917\n org.telegram.ui.Components.WallpaperCheckBoxView[] r2 = r6.messagesCheckBoxView\n org.telegram.ui.Components.WallpaperCheckBoxView r12 = new org.telegram.ui.Components.WallpaperCheckBoxView\n if (r1 != 0) goto L_0x08b8\n r13 = 1\n goto L_0x08b9\n L_0x08b8:\n r13 = 0\n L_0x08b9:\n org.telegram.ui.Components.BackupImageView r15 = r6.backgroundImage\n r12.<init>(r7, r13, r15)\n r2[r1] = r12\n org.telegram.ui.Components.WallpaperCheckBoxView[] r2 = r6.messagesCheckBoxView\n r2 = r2[r1]\n r12 = r3[r1]\n r13 = r10[r1]\n r2.setText(r12, r13, r11)\n if (r1 != 0) goto L_0x08d8\n org.telegram.ui.Components.WallpaperCheckBoxView[] r2 = r6.messagesCheckBoxView\n r2 = r2[r1]\n org.telegram.ui.ActionBar.Theme$ThemeAccent r12 = r6.accent\n boolean r12 = r12.myMessagesAnimated\n r2.setChecked(r12, r9)\n L_0x08d8:\n r2 = 1113587712(0x42600000, float:56.0)\n int r12 = org.telegram.messenger.AndroidUtilities.dp(r2)\n int r12 = r12 + r11\n android.widget.FrameLayout$LayoutParams r13 = new android.widget.FrameLayout$LayoutParams\n r13.<init>(r12, r5)\n r15 = 17\n r13.gravity = r15\n if (r1 != r8) goto L_0x08f4\n int r12 = r12 / 2\n int r15 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r12 = r12 + r15\n r13.leftMargin = r12\n goto L_0x08fd\n L_0x08f4:\n int r12 = r12 / 2\n int r15 = org.telegram.messenger.AndroidUtilities.dp(r18)\n int r12 = r12 + r15\n r13.rightMargin = r12\n L_0x08fd:\n android.widget.FrameLayout r12 = r6.messagesButtonsContainer\n org.telegram.ui.Components.WallpaperCheckBoxView[] r15 = r6.messagesCheckBoxView\n r15 = r15[r1]\n r12.addView(r15, r13)\n org.telegram.ui.Components.WallpaperCheckBoxView[] r12 = r6.messagesCheckBoxView\n r13 = r12[r1]\n r12 = r12[r1]\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda12 r15 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda12\n r15.<init>(r6, r1, r13)\n r12.setOnClickListener(r15)\n int r1 = r1 + 1\n goto L_0x08ad\n L_0x0917:\n int r1 = r6.screenType\n if (r1 == r8) goto L_0x0921\n java.lang.Object r1 = r6.currentWallpaper\n boolean r1 = r1 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r1 == 0) goto L_0x0CLASSNAME\n L_0x0921:\n r6.isBlurred = r9\n r1 = 0\n L_0x0924:\n r2 = 2\n if (r1 >= r2) goto L_0x0CLASSNAME\n android.widget.FrameLayout[] r3 = r6.patternLayout\n org.telegram.ui.ThemePreviewActivity$16 r10 = new org.telegram.ui.ThemePreviewActivity$16\n r10.<init>(r7, r1, r0)\n r3[r1] = r10\n if (r1 == r8) goto L_0x0936\n int r3 = r6.screenType\n if (r3 != r2) goto L_0x093d\n L_0x0936:\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n r2.setVisibility(r14)\n L_0x093d:\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n r2.setWillNotDraw(r9)\n int r2 = r6.screenType\n r3 = 2\n if (r2 != r3) goto L_0x0958\n if (r1 != 0) goto L_0x094e\n r2 = 321(0x141, float:4.5E-43)\n goto L_0x0950\n L_0x094e:\n r2 = 316(0x13c, float:4.43E-43)\n L_0x0950:\n r3 = 83\n r10 = -1\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r10, r2, r3)\n goto L_0x0966\n L_0x0958:\n r3 = 83\n r10 = -1\n if (r1 != 0) goto L_0x0960\n r2 = 273(0x111, float:3.83E-43)\n goto L_0x0962\n L_0x0960:\n r2 = 316(0x13c, float:4.43E-43)\n L_0x0962:\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r10, r2, r3)\n L_0x0966:\n if (r1 != 0) goto L_0x0986\n int r3 = r2.height\n r10 = 1094713344(0x41400000, float:12.0)\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r10)\n int r11 = r0.top\n int r10 = r10 + r11\n int r3 = r3 + r10\n r2.height = r3\n android.widget.FrameLayout[] r3 = r6.patternLayout\n r3 = r3[r1]\n r10 = 1094713344(0x41400000, float:12.0)\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r10)\n int r11 = r0.top\n int r10 = r10 + r11\n r3.setPadding(r9, r10, r9, r9)\n L_0x0986:\n android.widget.FrameLayout r3 = r6.page2\n android.widget.FrameLayout[] r10 = r6.patternLayout\n r10 = r10[r1]\n r3.addView(r10, r2)\n r2 = 1101529088(0x41a80000, float:21.0)\n if (r1 == r8) goto L_0x0998\n int r3 = r6.screenType\n r10 = 2\n if (r3 != r10) goto L_0x0ad6\n L_0x0998:\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n org.telegram.ui.ThemePreviewActivity$17 r10 = new org.telegram.ui.ThemePreviewActivity$17\n r10.<init>(r6, r7)\n r3[r1] = r10\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n r3 = r3[r1]\n r3.setWillNotDraw(r9)\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n r3 = r3[r1]\n r10 = 1077936128(0x40400000, float:3.0)\n int r10 = org.telegram.messenger.AndroidUtilities.dp(r10)\n r3.setPadding(r9, r10, r9, r9)\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n r3 = r3[r1]\n r3.setClickable(r8)\n android.widget.FrameLayout[] r3 = r6.patternLayout\n r3 = r3[r1]\n android.widget.FrameLayout[] r10 = r6.patternsButtonsContainer\n r11 = r10[r1]\n r10 = 80\n r12 = 51\n r13 = -1\n android.widget.FrameLayout$LayoutParams r15 = org.telegram.ui.Components.LayoutHelper.createFrame(r13, r12, r10)\n r3.addView(r11, r15)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n android.widget.TextView r11 = new android.widget.TextView\n r11.<init>(r7)\n r3[r1] = r11\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n r11 = 1097859072(0x41700000, float:15.0)\n r3.setTextSize(r8, r11)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n android.graphics.Typeface r11 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r3.setTypeface(r11)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n int r11 = org.telegram.ui.ActionBar.Theme.getColor(r28)\n r3.setTextColor(r11)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n r11 = 2131624667(0x7f0e02db, float:1.887652E38)\n java.lang.String r12 = \"Cancel\"\n java.lang.String r11 = org.telegram.messenger.LocaleController.getString(r12, r11)\n java.lang.String r11 = r11.toUpperCase()\n r3.setText(r11)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n r11 = 17\n r3.setGravity(r11)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n int r11 = org.telegram.messenger.AndroidUtilities.dp(r2)\n int r12 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r3.setPadding(r11, r9, r12, r9)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n java.lang.String r11 = \"listSelectorSDK21\"\n int r11 = org.telegram.ui.ActionBar.Theme.getColor(r11)\n android.graphics.drawable.Drawable r11 = org.telegram.ui.ActionBar.Theme.createSelectorDrawable(r11, r9)\n r3.setBackgroundDrawable(r11)\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n r3 = r3[r1]\n android.widget.TextView[] r11 = r6.patternsCancelButton\n r11 = r11[r1]\n r10 = 51\n r12 = -1\n android.widget.FrameLayout$LayoutParams r13 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r12, r10)\n r3.addView(r11, r13)\n android.widget.TextView[] r3 = r6.patternsCancelButton\n r3 = r3[r1]\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda10 r11 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda10\n r11.<init>(r6, r1)\n r3.setOnClickListener(r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n android.widget.TextView r11 = new android.widget.TextView\n r11.<init>(r7)\n r3[r1] = r11\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n r11 = 1097859072(0x41700000, float:15.0)\n r3.setTextSize(r8, r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n android.graphics.Typeface r11 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r3.setTypeface(r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n int r11 = org.telegram.ui.ActionBar.Theme.getColor(r28)\n r3.setTextColor(r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n r11 = 2131624299(0x7f0e016b, float:1.8875774E38)\n java.lang.String r12 = \"ApplyTheme\"\n java.lang.String r11 = org.telegram.messenger.LocaleController.getString(r12, r11)\n java.lang.String r11 = r11.toUpperCase()\n r3.setText(r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n r11 = 17\n r3.setGravity(r11)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n int r11 = org.telegram.messenger.AndroidUtilities.dp(r2)\n int r12 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r3.setPadding(r11, r9, r12, r9)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n java.lang.String r11 = \"listSelectorSDK21\"\n int r11 = org.telegram.ui.ActionBar.Theme.getColor(r11)\n android.graphics.drawable.Drawable r11 = org.telegram.ui.ActionBar.Theme.createSelectorDrawable(r11, r9)\n r3.setBackgroundDrawable(r11)\n android.widget.FrameLayout[] r3 = r6.patternsButtonsContainer\n r3 = r3[r1]\n android.widget.TextView[] r11 = r6.patternsSaveButton\n r11 = r11[r1]\n r12 = 53\n r13 = -1\n android.widget.FrameLayout$LayoutParams r12 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r13, r12)\n r3.addView(r11, r12)\n android.widget.TextView[] r3 = r6.patternsSaveButton\n r3 = r3[r1]\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda9 r11 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda9\n r11.<init>(r6, r1)\n r3.setOnClickListener(r11)\n L_0x0ad6:\n if (r1 != r8) goto L_0x0bd6\n android.widget.TextView r3 = new android.widget.TextView\n r3.<init>(r7)\n r3.setLines(r8)\n r3.setSingleLine(r8)\n r11 = 2131624532(0x7f0e0254, float:1.8876246E38)\n java.lang.String r12 = \"BackgroundChoosePattern\"\n java.lang.String r11 = org.telegram.messenger.LocaleController.getString(r12, r11)\n r3.setText(r11)\n java.lang.String r11 = \"windowBackgroundWhiteBlackText\"\n int r11 = org.telegram.ui.ActionBar.Theme.getColor(r11)\n r3.setTextColor(r11)\n r11 = 1101004800(0x41a00000, float:20.0)\n r3.setTextSize(r8, r11)\n android.graphics.Typeface r11 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r3.setTypeface(r11)\n int r11 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r12 = 1086324736(0x40CLASSNAME, float:6.0)\n int r12 = org.telegram.messenger.AndroidUtilities.dp(r12)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r13 = 1090519040(0x41000000, float:8.0)\n int r13 = org.telegram.messenger.AndroidUtilities.dp(r13)\n r3.setPadding(r11, r12, r2, r13)\n android.text.TextUtils$TruncateAt r2 = android.text.TextUtils.TruncateAt.MIDDLE\n r3.setEllipsize(r2)\n r2 = 16\n r3.setGravity(r2)\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n r29 = -1\n r30 = 1111490560(0x42400000, float:48.0)\n r31 = 51\n r32 = 0\n r33 = 1101529088(0x41a80000, float:21.0)\n r34 = 0\n r35 = 0\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r29, r30, r31, r32, r33, r34, r35)\n r2.addView(r3, r11)\n org.telegram.ui.ThemePreviewActivity$18 r2 = new org.telegram.ui.ThemePreviewActivity$18\n r2.<init>(r6, r7)\n r6.patternsListView = r2\n androidx.recyclerview.widget.LinearLayoutManager r3 = new androidx.recyclerview.widget.LinearLayoutManager\n r3.<init>(r7, r9, r9)\n r6.patternsLayoutManager = r3\n r2.setLayoutManager(r3)\n org.telegram.ui.Components.RecyclerListView r2 = r6.patternsListView\n org.telegram.ui.ThemePreviewActivity$PatternsAdapter r3 = new org.telegram.ui.ThemePreviewActivity$PatternsAdapter\n r3.<init>(r7)\n r6.patternsAdapter = r3\n r2.setAdapter(r3)\n org.telegram.ui.Components.RecyclerListView r2 = r6.patternsListView\n org.telegram.ui.ThemePreviewActivity$19 r3 = new org.telegram.ui.ThemePreviewActivity$19\n r3.<init>(r6)\n r2.addItemDecoration(r3)\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n org.telegram.ui.Components.RecyclerListView r3 = r6.patternsListView\n r30 = 1120403456(0x42CLASSNAME, float:100.0)\n r33 = 1117257728(0x42980000, float:76.0)\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r29, r30, r31, r32, r33, r34, r35)\n r2.addView(r3, r11)\n org.telegram.ui.Components.RecyclerListView r2 = r6.patternsListView\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda23 r3 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda23\n r3.<init>(r6)\n r2.setOnItemClickListener((org.telegram.ui.Components.RecyclerListView.OnItemClickListener) r3)\n org.telegram.ui.Cells.HeaderCell r2 = new org.telegram.ui.Cells.HeaderCell\n r2.<init>(r7)\n r6.intensityCell = r2\n r3 = 2131624539(0x7f0e025b, float:1.887626E38)\n java.lang.String r11 = \"BackgroundIntensity\"\n java.lang.String r3 = org.telegram.messenger.LocaleController.getString(r11, r3)\n r2.setText(r3)\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n org.telegram.ui.Cells.HeaderCell r3 = r6.intensityCell\n r30 = -1073741824(0xffffffffCLASSNAME, float:-2.0)\n r33 = 1127153664(0x432var_, float:175.0)\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r29, r30, r31, r32, r33, r34, r35)\n r2.addView(r3, r11)\n org.telegram.ui.ThemePreviewActivity$20 r2 = new org.telegram.ui.ThemePreviewActivity$20\n r2.<init>(r6, r7)\n r6.intensitySeekBar = r2\n float r3 = r6.currentIntensity\n r2.setProgress(r3)\n org.telegram.ui.Components.SeekBarView r2 = r6.intensitySeekBar\n r2.setReportChanges(r8)\n org.telegram.ui.Components.SeekBarView r2 = r6.intensitySeekBar\n org.telegram.ui.ThemePreviewActivity$21 r3 = new org.telegram.ui.ThemePreviewActivity$21\n r3.<init>()\n r2.setDelegate(r3)\n android.widget.FrameLayout[] r2 = r6.patternLayout\n r2 = r2[r1]\n org.telegram.ui.Components.SeekBarView r3 = r6.intensitySeekBar\n r30 = 1108869120(0x42180000, float:38.0)\n r32 = 1084227584(0x40a00000, float:5.0)\n r33 = 1129512960(0x43530000, float:211.0)\n r34 = 1084227584(0x40a00000, float:5.0)\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r29, r30, r31, r32, r33, r34, r35)\n r2.addView(r3, r11)\n goto L_0x0CLASSNAME\n L_0x0bd6:\n org.telegram.ui.Components.ColorPicker r2 = new org.telegram.ui.Components.ColorPicker\n boolean r3 = r6.editingTheme\n org.telegram.ui.ThemePreviewActivity$22 r11 = new org.telegram.ui.ThemePreviewActivity$22\n r11.<init>()\n r2.<init>(r7, r3, r11)\n r6.colorPicker = r2\n int r3 = r6.screenType\n if (r3 != r8) goto L_0x0c4a\n android.widget.FrameLayout[] r3 = r6.patternLayout\n r3 = r3[r1]\n r11 = -1\n android.widget.FrameLayout$LayoutParams r12 = org.telegram.ui.Components.LayoutHelper.createFrame(r11, r11, r8)\n r3.addView(r2, r12)\n org.telegram.ui.ActionBar.Theme$ThemeInfo r2 = r6.applyingTheme\n boolean r2 = r2.isDark()\n if (r2 == 0) goto L_0x0CLASSNAME\n org.telegram.ui.Components.ColorPicker r2 = r6.colorPicker\n r3 = 1045220557(0x3e4ccccd, float:0.2)\n r2.setMinBrightness(r3)\n goto L_0x0CLASSNAME\n L_0x0CLASSNAME:\n org.telegram.ui.Components.ColorPicker r2 = r6.colorPicker\n r3 = 1028443341(0x3d4ccccd, float:0.05)\n r2.setMinBrightness(r3)\n org.telegram.ui.Components.ColorPicker r2 = r6.colorPicker\n r3 = 1061997773(0x3f4ccccd, float:0.8)\n r2.setMaxBrightness(r3)\n L_0x0CLASSNAME:\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.accentColor2\n if (r2 == 0) goto L_0x0c1e\n r33 = 2\n goto L_0x0CLASSNAME\n L_0x0c1e:\n r33 = 1\n L_0x0CLASSNAME:\n org.telegram.ui.Components.ColorPicker r2 = r6.colorPicker\n r30 = 1\n boolean r31 = r6.hasChanges(r8)\n r32 = 2\n r34 = 0\n r35 = 0\n r36 = 0\n r29 = r2\n r29.setType(r30, r31, r32, r33, r34, r35, r36)\n org.telegram.ui.Components.ColorPicker r2 = r6.colorPicker\n org.telegram.ui.ActionBar.Theme$ThemeAccent r3 = r6.accent\n int r3 = r3.accentColor\n r2.setColor(r3, r9)\n org.telegram.ui.ActionBar.Theme$ThemeAccent r2 = r6.accent\n int r2 = r2.accentColor2\n if (r2 == 0) goto L_0x0CLASSNAME\n org.telegram.ui.Components.ColorPicker r3 = r6.colorPicker\n r3.setColor(r2, r8)\n goto L_0x0CLASSNAME\n L_0x0c4a:\n android.widget.FrameLayout[] r3 = r6.patternLayout\n r3 = r3[r1]\n r29 = -1\n r30 = -1082130432(0xffffffffbvar_, float:-1.0)\n r31 = 1\n r32 = 0\n r33 = 0\n r34 = 0\n r35 = 1111490560(0x42400000, float:48.0)\n android.widget.FrameLayout$LayoutParams r11 = org.telegram.ui.Components.LayoutHelper.createFrame(r29, r30, r31, r32, r33, r34, r35)\n r3.addView(r2, r11)\n L_0x0CLASSNAME:\n int r1 = r1 + 1\n goto L_0x0924\n L_0x0CLASSNAME:\n r6.updateButtonState(r9, r9)\n org.telegram.ui.Components.BackupImageView r0 = r6.backgroundImage\n org.telegram.messenger.ImageReceiver r0 = r0.getImageReceiver()\n boolean r0 = r0.hasBitmapImage()\n if (r0 != 0) goto L_0x0c7d\n android.widget.FrameLayout r0 = r6.page2\n r1 = -16777216(0xfffffffffvar_, float:-1.7014118E38)\n r0.setBackgroundColor(r1)\n L_0x0c7d:\n int r0 = r6.screenType\n if (r0 == r8) goto L_0x0CLASSNAME\n java.lang.Object r0 = r6.currentWallpaper\n boolean r0 = r0 instanceof org.telegram.ui.WallpapersListActivity.ColorWallpaper\n if (r0 != 0) goto L_0x0CLASSNAME\n org.telegram.ui.Components.BackupImageView r0 = r6.backgroundImage\n org.telegram.messenger.ImageReceiver r0 = r0.getImageReceiver()\n r0.setCrossfadeWithOldImage(r8)\n L_0x0CLASSNAME:\n org.telegram.ui.Components.RecyclerListView r0 = r6.listView2\n org.telegram.ui.ThemePreviewActivity$MessagesAdapter r1 = r6.messagesAdapter\n r0.setAdapter(r1)\n org.telegram.ui.ThemePreviewActivity$23 r0 = new org.telegram.ui.ThemePreviewActivity$23\n r0.<init>(r7)\n r6.frameLayout = r0\n r0.setWillNotDraw(r9)\n android.widget.FrameLayout r0 = r6.frameLayout\n r6.fragmentView = r0\n android.view.ViewTreeObserver r0 = r0.getViewTreeObserver()\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda13 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda13\n r1.<init>(r6)\n r6.onGlobalLayoutListener = r1\n r0.addOnGlobalLayoutListener(r1)\n androidx.viewpager.widget.ViewPager r0 = new androidx.viewpager.widget.ViewPager\n r0.<init>(r7)\n r6.viewPager = r0\n org.telegram.ui.ThemePreviewActivity$24 r1 = new org.telegram.ui.ThemePreviewActivity$24\n r1.<init>()\n r0.addOnPageChangeListener(r1)\n androidx.viewpager.widget.ViewPager r0 = r6.viewPager\n org.telegram.ui.ThemePreviewActivity$25 r1 = new org.telegram.ui.ThemePreviewActivity$25\n r1.<init>()\n r0.setAdapter(r1)\n androidx.viewpager.widget.ViewPager r0 = r6.viewPager\n java.lang.String r1 = \"actionBarDefault\"\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r1)\n org.telegram.messenger.AndroidUtilities.setViewPagerEdgeEffectColor(r0, r1)\n android.widget.FrameLayout r0 = r6.frameLayout\n androidx.viewpager.widget.ViewPager r1 = r6.viewPager\n r11 = -1\n r12 = -1082130432(0xffffffffbvar_, float:-1.0)\n r13 = 51\n r14 = 0\n r15 = 0\n r16 = 0\n int r2 = r6.screenType\n if (r2 != 0) goto L_0x0ced\n r2 = 1111490560(0x42400000, float:48.0)\n r17 = 1111490560(0x42400000, float:48.0)\n goto L_0x0cef\n L_0x0ced:\n r17 = 0\n L_0x0cef:\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r11, r12, r13, r14, r15, r16, r17)\n r0.addView(r1, r2)\n org.telegram.ui.Components.UndoView r0 = new org.telegram.ui.Components.UndoView\n r0.<init>(r7, r6)\n r6.undoView = r0\n r1 = 1112276992(0x424CLASSNAME, float:51.0)\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r1)\n float r1 = (float) r1\n r0.setAdditionalTranslationY(r1)\n android.widget.FrameLayout r0 = r6.frameLayout\n org.telegram.ui.Components.UndoView r1 = r6.undoView\n r11 = -1\n r12 = -1073741824(0xffffffffCLASSNAME, float:-2.0)\n r13 = 83\n r14 = 1090519040(0x41000000, float:8.0)\n r15 = 0\n r16 = 1090519040(0x41000000, float:8.0)\n r17 = 1090519040(0x41000000, float:8.0)\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r11, r12, r13, r14, r15, r16, r17)\n r0.addView(r1, r2)\n int r0 = r6.screenType\n if (r0 != 0) goto L_0x0e51\n android.view.View r0 = new android.view.View\n r0.<init>(r7)\n java.lang.String r1 = \"dialogShadowLine\"\n int r1 = org.telegram.ui.ActionBar.Theme.getColor(r1)\n r0.setBackgroundColor(r1)\n android.widget.FrameLayout$LayoutParams r1 = new android.widget.FrameLayout$LayoutParams\n r2 = 83\n r3 = -1\n r1.<init>(r3, r8, r2)\n r2 = 1111490560(0x42400000, float:48.0)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r1.bottomMargin = r2\n android.widget.FrameLayout r2 = r6.frameLayout\n r2.addView(r0, r1)\n android.widget.FrameLayout r0 = new android.widget.FrameLayout\n r0.<init>(r7)\n r6.saveButtonsContainer = r0\n java.lang.String r1 = \"windowBackgroundWhite\"\n int r1 = r6.getButtonsColor(r1)\n r0.setBackgroundColor(r1)\n android.widget.FrameLayout r0 = r6.frameLayout\n android.widget.FrameLayout r1 = r6.saveButtonsContainer\n r2 = 83\n r3 = 48\n r4 = -1\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r4, r3, r2)\n r0.addView(r1, r2)\n org.telegram.ui.ThemePreviewActivity$26 r0 = new org.telegram.ui.ThemePreviewActivity$26\n r0.<init>(r7)\n r6.dotsContainer = r0\n android.widget.FrameLayout r1 = r6.saveButtonsContainer\n r2 = 22\n r3 = 8\n r4 = 17\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r2, r3, r4)\n r1.addView(r0, r2)\n android.widget.TextView r0 = new android.widget.TextView\n r0.<init>(r7)\n r6.cancelButton = r0\n r1 = 1096810496(0x41600000, float:14.0)\n r0.setTextSize(r8, r1)\n android.widget.TextView r0 = r6.cancelButton\n r1 = r28\n int r2 = r6.getButtonsColor(r1)\n r0.setTextColor(r2)\n android.widget.TextView r0 = r6.cancelButton\n r0.setGravity(r4)\n android.widget.TextView r0 = r6.cancelButton\n r2 = 251658240(0xvar_, float:6.3108872E-30)\n android.graphics.drawable.Drawable r2 = org.telegram.ui.ActionBar.Theme.createSelectorDrawable(r2, r9)\n r0.setBackgroundDrawable(r2)\n android.widget.TextView r0 = r6.cancelButton\n r2 = 1105723392(0x41e80000, float:29.0)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r3 = 1105723392(0x41e80000, float:29.0)\n int r3 = org.telegram.messenger.AndroidUtilities.dp(r3)\n r0.setPadding(r2, r9, r3, r9)\n android.widget.TextView r0 = r6.cancelButton\n r2 = 2131624667(0x7f0e02db, float:1.887652E38)\n java.lang.String r3 = \"Cancel\"\n java.lang.String r2 = org.telegram.messenger.LocaleController.getString(r3, r2)\n java.lang.String r2 = r2.toUpperCase()\n r0.setText(r2)\n android.widget.TextView r0 = r6.cancelButton\n android.graphics.Typeface r2 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r0.setTypeface(r2)\n android.widget.FrameLayout r0 = r6.saveButtonsContainer\n android.widget.TextView r2 = r6.cancelButton\n r3 = 51\n r4 = -1\n android.widget.FrameLayout$LayoutParams r3 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r4, r3)\n r0.addView(r2, r3)\n android.widget.TextView r0 = r6.cancelButton\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda5 r2 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda5\n r2.<init>(r6)\n r0.setOnClickListener(r2)\n android.widget.TextView r0 = new android.widget.TextView\n r0.<init>(r7)\n r6.doneButton = r0\n r2 = 1096810496(0x41600000, float:14.0)\n r0.setTextSize(r8, r2)\n android.widget.TextView r0 = r6.doneButton\n int r1 = r6.getButtonsColor(r1)\n r0.setTextColor(r1)\n android.widget.TextView r0 = r6.doneButton\n r1 = 17\n r0.setGravity(r1)\n android.widget.TextView r0 = r6.doneButton\n r1 = 251658240(0xvar_, float:6.3108872E-30)\n android.graphics.drawable.Drawable r1 = org.telegram.ui.ActionBar.Theme.createSelectorDrawable(r1, r9)\n r0.setBackgroundDrawable(r1)\n android.widget.TextView r0 = r6.doneButton\n r1 = 1105723392(0x41e80000, float:29.0)\n int r1 = org.telegram.messenger.AndroidUtilities.dp(r1)\n r2 = 1105723392(0x41e80000, float:29.0)\n int r2 = org.telegram.messenger.AndroidUtilities.dp(r2)\n r0.setPadding(r1, r9, r2, r9)\n android.widget.TextView r0 = r6.doneButton\n r1 = 2131624299(0x7f0e016b, float:1.8875774E38)\n java.lang.String r2 = \"ApplyTheme\"\n java.lang.String r1 = org.telegram.messenger.LocaleController.getString(r2, r1)\n java.lang.String r1 = r1.toUpperCase()\n r0.setText(r1)\n android.widget.TextView r0 = r6.doneButton\n android.graphics.Typeface r1 = org.telegram.messenger.AndroidUtilities.getTypeface(r19)\n r0.setTypeface(r1)\n android.widget.FrameLayout r0 = r6.saveButtonsContainer\n android.widget.TextView r1 = r6.doneButton\n r2 = 53\n r3 = -1\n android.widget.FrameLayout$LayoutParams r2 = org.telegram.ui.Components.LayoutHelper.createFrame(r5, r3, r2)\n r0.addView(r1, r2)\n android.widget.TextView r0 = r6.doneButton\n org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda6 r1 = new org.telegram.ui.ThemePreviewActivity$$ExternalSyntheticLambda6\n r1.<init>(r6)\n r0.setOnClickListener(r1)\n L_0x0e51:\n int r0 = r6.screenType\n if (r0 != r8) goto L_0x0e6c\n boolean r0 = org.telegram.ui.ActionBar.Theme.hasCustomWallpaper()\n if (r0 != 0) goto L_0x0e6c\n org.telegram.ui.ActionBar.Theme$ThemeAccent r0 = r6.accent\n long r0 = r0.backgroundOverrideColor\n r2 = 4294967296(0xNUM, double:2.121995791E-314)\n int r4 = (r0 > r2 ? 1 : (r0 == r2 ? 0 : -1))\n if (r4 == 0) goto L_0x0e6c\n r0 = 2\n r6.selectColorType(r0)\n L_0x0e6c:\n java.util.List r0 = r37.getThemeDescriptionsInternal()\n r6.themeDescriptions = r0\n r6.setCurrentImage(r8)\n r6.updatePlayAnimationView(r9)\n boolean r0 = r6.showColor\n if (r0 == 0) goto L_0x0e7f\n r6.showPatternsView(r9, r8, r9)\n L_0x0e7f:\n android.view.View r0 = r6.fragmentView\n return r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: org.telegram.ui.ThemePreviewActivity.createView(android.content.Context):android.view.View\");\n }", "private void createToolBarActions() {\r\n\t\t// create the action\r\n\t\tGetMessage<Transport> getMessage = new GetMessage<Transport>(new Transport());\r\n\t\tgetMessage.addParameter(IFilterTypes.TRANSPORT_TODO_FILTER, \"\");\r\n\r\n\t\t// add to the toolbar\r\n\t\tform.getToolBarManager().add(new RefreshViewAction<Transport>(getMessage));\r\n\t\tform.getToolBarManager().update(true);\r\n\t}", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void initCollapsingToolbar() {\n final CollapsingToolbarLayout collapsingToolbar =\n (CollapsingToolbarLayout) findViewById(R.id.collapsing_toolbar);\n collapsingToolbar.setTitle(\" \");\n AppBarLayout appBarLayout = (AppBarLayout) findViewById(R.id.appbar);\n appBarLayout.setExpanded(true);\n\n // hiding & showing the title when toolbar expanded & collapsed\n appBarLayout.addOnOffsetChangedListener(new AppBarLayout.OnOffsetChangedListener() {\n boolean isShow = false;\n int scrollRange = -1;\n\n @Override\n public void onOffsetChanged(AppBarLayout appBarLayout, int verticalOffset) {\n if (scrollRange == -1) {\n scrollRange = appBarLayout.getTotalScrollRange();\n }\n if (scrollRange + verticalOffset == 0) {\n collapsingToolbar.setTitle(getString(R.string.app_name));\n isShow = true;\n } else if (isShow) {\n collapsingToolbar.setTitle(\" \");\n isShow = false;\n }\n }\n });\n }", "private void showPermissionSnackbar() {\n Snackbar.make(\n findViewById(R.id.container), R.string.permission_explanation, Snackbar.LENGTH_LONG)\n .setAction(R.string.permission_explanation_action, new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n requestFineLocationPermission();\n }\n })\n .show();\n }", "@Override\n\tprotected ToolBarManager createToolBarManager(int style) {\n\t\treturn null;\n\t}", "void showErrorSnackbar(long syncInterval) {\r\n // Initialize the the parameters that will be used to create the String message\r\n int timePassed;\r\n String timeUnit;\r\n if (syncInterval < DAY_IN_SECONDS) {\r\n // If less than a day has passed, convert the number of seconds to hours\r\n timePassed = (int) (syncInterval / HOUR_IN_SECONDS);\r\n\r\n // Set the time unit to singular or multiple\r\n if (timePassed == 1) {\r\n timeUnit = getString(R.string.hour_singular);\r\n } else {\r\n timeUnit = getString(R.string.hour_multiple);\r\n }\r\n\r\n } else {\r\n // Convert the time passed to days\r\n timePassed = (int) (syncInterval / DAY_IN_SECONDS);\r\n\r\n // Set the time unit to singular or multiple\r\n if (timePassed == 1) {\r\n timeUnit = getString(R.string.day_singular);\r\n } else {\r\n timeUnit = getString(R.string.day_multiple);\r\n }\r\n }\r\n\r\n // Create the String message to display to the user to notify them of how long\r\n // since the last sync\r\n String timeString = getString(R.string.error_last_sync, timePassed + \" \" + timeUnit);\r\n\r\n // Create a Snackbar to hold the message\r\n mSnackBar = Snackbar.make(mDrawerLayout,\r\n timeString,\r\n Snackbar.LENGTH_INDEFINITE\r\n );\r\n\r\n // Set the Snackbar to be dismissed on click\r\n mSnackBar.getView().setOnClickListener(new View.OnClickListener() {\r\n @Override\r\n public void onClick(View view) {\r\n mSnackBar.dismiss();\r\n }\r\n });\r\n\r\n // Show the Snackbar\r\n mSnackBar.show();\r\n }", "private void create_toolbar() {\n setSupportActionBar(toolbar);\n getSupportActionBar().setTitle(\"Event Planner\");//this will set the title of our application\n\n }", "private void createUsageBarCheck (final Shell shell, final ProgressBar usage) {\n \tnew Thread(new Runnable() {\n \t\t\tpublic void run() {\n \t\t\t\twhile (!stop) {\n \t\t\t\t\ttry {\n \t\t\t\t\t\tThread.sleep(1000);\n \t\t\t\t\t} catch (Exception e) {\n \t\t\t\t\t\tlog.error(e.getMessage());\n \t\t\t\t\t}\n \t\t\t\t\tif (!shell.isDisposed()) {\n \t\t\t\t\t\ttoolbar.getDisplay().asyncExec(new Runnable() {\n \t\t\t\t\t\t\tpublic void run() {\n \t\t\t\t\t\t\t\tdouble max = (double) Runtime.getRuntime().maxMemory();\n \t\t\t\t\t\t\t\tdouble fraction = max - (double) Runtime.getRuntime().freeMemory();\n \t\t\t\t\t\t\t\tdouble selection = (fraction / max) * 100;\n \t\t\t\t\t\t\t\tRuntime.getRuntime().gc();\n \t\t\t\t\t\t\t\tint selection_int = (int) (selection);\n \t\t\t\t\t\t \tusage.setSelection(selection_int);\n \t\t\t\t\t\t\t}\n \t\t\t\t\t\t});\n \t\t\t\t\t}\n \t\t\t\t}\n \t\t\t}\n \t\t}).start();\n }", "private void actionbarInit() \n\t{\n\t\tactionbar_ll_left.setVisibility(View.VISIBLE);\n\t\tactionbar_tv_back_name_left.setVisibility(View.GONE);\t\t\n\t\t\n\t\tactionbar_btn_right_left.setVisibility(View.GONE);\n\t\tactionbar_imgbtn_right.setVisibility(View.GONE);\n\n\t\tactionbar_tv_back_name_left.setText(\"\");\n\t\tactionbar_tv_name_center.setText(getString(R.string.set));\n\t\tactionbar_btn_right_left.setText(getString(R.string.rule));\n\n\t\tactionbar_ll_left.setOnClickListener(clickListener_actionbar);\n//\t\tactionbar_imgbtn_right.setOnClickListener(clickListener_actionbar);\n\t}", "private void recreateOptionPaneMessage(JOptionPane optionPane)\r\n/* */ {\r\n/* 175 */ Object message = optionPane.getMessage();\r\n/* 176 */ if ((message instanceof String)) {\r\n/* 177 */ Font font = optionPane.getFont();\r\n/* 178 */ final JTextArea textArea = new JTextArea((String)message);\r\n/* 179 */ textArea.setFont(font);\r\n/* 180 */ int lh = textArea.getFontMetrics(font).getHeight();\r\n/* 181 */ Insets margin = new Insets(0, 0, lh, 24);\r\n/* 182 */ textArea.setMargin(margin);\r\n/* 183 */ textArea.setEditable(false);\r\n/* 184 */ textArea.setWrapStyleWord(true);\r\n/* 185 */ textArea.setBackground(optionPane.getBackground());\r\n/* 186 */ JPanel panel = new JPanel(new BorderLayout());\r\n/* 187 */ panel.add(textArea, \"Center\");\r\n/* 188 */ final JProgressBar progressBar = new JProgressBar();\r\n/* 189 */ progressBar.setName(\"BlockingDialog.progressBar\");\r\n/* 190 */ progressBar.setIndeterminate(true);\r\n/* 191 */ PropertyChangeListener taskPCL = new PropertyChangeListener() {\r\n/* */ public void propertyChange(PropertyChangeEvent e) {\r\n/* 193 */ if (\"progress\".equals(e.getPropertyName())) {\r\n/* 194 */ progressBar.setIndeterminate(false);\r\n/* 195 */ progressBar.setValue(((Integer)e.getNewValue()).intValue());\r\n/* 196 */ DefaultInputBlocker.this.updateStatusBarString(progressBar);\r\n/* */ }\r\n/* 198 */ else if (\"message\".equals(e.getPropertyName())) {\r\n/* 199 */ textArea.setText((String)e.getNewValue());\r\n/* */ }\r\n/* */ }\r\n/* 202 */ };\r\n/* 203 */ getTask().addPropertyChangeListener(taskPCL);\r\n/* 204 */ panel.add(progressBar, \"South\");\r\n/* 205 */ injectBlockingDialogComponents(panel);\r\n/* 206 */ optionPane.setMessage(panel);\r\n/* */ }\r\n/* */ }", "private void createResponseToolbar ( ExpandableComposite parent ) {\n \t\trawAction = new ShowRawAction();\n \t\trawAction.setChecked(true);\n \t\tbrowserAction = new ShowInBrowserAction();\n \n \t\tToolBarManager toolBarManager = new ToolBarManager(SWT.FLAT);\n \t\tToolBar toolbar = toolBarManager.createControl(parent);\n \n \t\ttoolBarManager.add(new FileSaveAction());\n \t\ttoolBarManager.add(new OpenInXMLEditorAction());\n \t\ttoolBarManager.add(rawAction);\n \t\ttoolBarManager.add(browserAction);\n \n \t\ttoolBarManager.update(true);\n \n \t\tparent.setTextClient(toolbar);\n \t}", "public static void showGreenSnackbar(String message, Activity activity, int snackbarDuration) {\n snackbar = Snackbar.make(activity.findViewById(android.R.id.content), message, snackbarDuration);\n View snackbarView = snackbar.getView();\n snackbarView.setBackgroundColor(Color.parseColor(GREEN));\n\n TextView snackbarText = snackbarView.findViewById(com.google.android.material.R.id.snackbar_text);\n snackbarText.setCompoundDrawablesWithIntrinsicBounds(R.drawable.ic_vector_checkmark, 0, 0, 0);\n snackbarText.setCompoundDrawablePadding(ICON_PADDING_SNACKBAR);\n snackbarText.setGravity(Gravity.CENTER);\n\n FrameLayout.LayoutParams params = (FrameLayout.LayoutParams)snackbarView.getLayoutParams();\n params.width = FrameLayout.LayoutParams.MATCH_PARENT;\n snackbarView.setLayoutParams(params);\n\n snackbar.show();\n }", "@Override\r\n\tprotected ToolBarManager createToolBarManager(int style) {\r\n\t\tToolBarManager toolBarManager = new ToolBarManager(style);\r\n\t\treturn toolBarManager;\r\n\t}", "private void setToolBarInfo() {\n mToolbar = (Toolbar)findViewById(R.id.toolbar);\n mToolbar.setTitle(\"Chatアプリ\");\n mToolbar.setTitleTextColor(-1);\n mToolbar.setNavigationIcon(R.drawable.common_google_signin_btn_icon_light);\n //setActionBar(toolbar);\n mToolbar.inflateMenu(R.menu.main_menu);\n mToolbar.setOnMenuItemClickListener(new Toolbar.OnMenuItemClickListener() {\n @Override\n public boolean onMenuItemClick(MenuItem item) {\n // メニューのクリック処理\n switch (item.getItemId()) {\n case R.id.sign_out_menu:\n mFirebaseAuth.signOut();\n Intent intent = new Intent();\n intent.setClassName(D.packageRoot, D.packageRoot + \".MainActivity\");\n startActivity(intent);\n return true;\n }\n return true;\n }\n });\n //setSupportActionBar(toolbar);\n }", "static /* synthetic */ void m89651a(NewChattingTabUI newChattingTabUI, Intent intent, boolean z) {\n boolean z2;\n AppMethodBeat.m2504i(29823);\n long currentTimeMillis = System.currentTimeMillis();\n if (newChattingTabUI.ypn == null) {\n newChattingTabUI.ypn = new ChattingUIFragment();\n newChattingTabUI.mChattingUIProxy = new C36230y(newChattingTabUI.iWA, newChattingTabUI.ypn);\n z2 = true;\n } else {\n z2 = false;\n }\n final int[] iArr;\n View dyW;\n final ViewGroup viewGroup;\n int statusBarHeight;\n if (newChattingTabUI.ypg == null) {\n if (newChattingTabUI.ypn.isSupportCustomActionBar()) {\n iArr = new int[2];\n newChattingTabUI.iWA.getSupportActionBar().getCustomView().getLocationInWindow(iArr);\n TestTimeForChatting testTimeForChatting = new TestTimeForChatting(newChattingTabUI.iWA);\n LayoutParams layoutParams = new LayoutParams(-1, -1);\n testTimeForChatting.setId(2131820582);\n newChattingTabUI.yph = testTimeForChatting.getId();\n testTimeForChatting.setOrientation(1);\n testTimeForChatting.setLayoutParams(layoutParams);\n final FitSystemWindowLayoutView fitSystemWindowLayoutView = new FitSystemWindowLayoutView(newChattingTabUI.iWA);\n fitSystemWindowLayoutView.setLayoutParams(new LayoutParams(-1, -1));\n dyW = newChattingTabUI.dyW();\n if (dyW == null) {\n C4990ab.m7420w(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"abRoot == null! try get child(0)\");\n dyW = ((ViewGroup) newChattingTabUI.iWA.getWindow().getDecorView()).getChildAt(0);\n }\n ImageView imageView = new ImageView(newChattingTabUI.iWA);\n imageView.setId(2131820648);\n imageView.setLayoutParams(layoutParams);\n imageView.setVisibility(8);\n C4990ab.m7416i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"[createChattingView] prepareView GONE\");\n viewGroup = (ViewGroup) dyW;\n ((ViewGroup) newChattingTabUI.iWA.getWindow().getDecorView()).removeView(dyW);\n dyW.setId(2131820633);\n fitSystemWindowLayoutView.addView(dyW);\n fitSystemWindowLayoutView.addView(imageView);\n fitSystemWindowLayoutView.addView(testTimeForChatting);\n ((ViewGroup) newChattingTabUI.iWA.getWindow().getDecorView()).addView(fitSystemWindowLayoutView);\n newChattingTabUI.iWA.getWindow().getDecorView().requestFitSystemWindows();\n statusBarHeight = C5230ak.getStatusBarHeight(newChattingTabUI.iWA);\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"ashu::fitSystemWindows. statusBarHeight:%d\", Integer.valueOf(statusBarHeight));\n if (statusBarHeight > 0) {\n newChattingTabUI.ype.mo56794a(fitSystemWindowLayoutView, new Rect(0, statusBarHeight, 0, 0), viewGroup);\n } else {\n newChattingTabUI.iWA.getSupportActionBar().getCustomView().post(new Runnable() {\n\n /* renamed from: com.tencent.mm.ui.NewChattingTabUI$3$1 */\n class C235601 implements OnApplyWindowInsetsListener {\n C235601() {\n }\n\n @TargetApi(20)\n public final WindowInsets onApplyWindowInsets(View view, WindowInsets windowInsets) {\n AppMethodBeat.m2504i(29794);\n if (windowInsets == null) {\n AppMethodBeat.m2505o(29794);\n } else {\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"OnApplyWindowInsetsListener %s\", windowInsets);\n windowInsets.consumeSystemWindowInsets();\n C36032b e = NewChattingTabUI.this.ype;\n FitSystemWindowLayoutView fitSystemWindowLayoutView = fitSystemWindowLayoutView;\n windowInsets.getSystemWindowInsetTop();\n e.mo56794a(fitSystemWindowLayoutView, new Rect(windowInsets.getSystemWindowInsetLeft(), windowInsets.getSystemWindowInsetTop(), windowInsets.getSystemWindowInsetRight(), windowInsets.getSystemWindowInsetBottom()), viewGroup);\n AppMethodBeat.m2505o(29794);\n }\n return windowInsets;\n }\n }\n\n public final void run() {\n AppMethodBeat.m2504i(29795);\n NewChattingTabUI.this.iWA.getSupportActionBar().getCustomView().getLocationInWindow(iArr);\n int statusBarHeight = C5230ak.getStatusBarHeight(NewChattingTabUI.this.iWA);\n if (statusBarHeight > 0) {\n NewChattingTabUI.this.ype.mo56794a(fitSystemWindowLayoutView, new Rect(0, statusBarHeight, 0, 0), viewGroup);\n AppMethodBeat.m2505o(29795);\n return;\n }\n if (C1443d.m3068iW(20)) {\n fitSystemWindowLayoutView.setOnApplyWindowInsetsListener(new C235601());\n }\n AppMethodBeat.m2505o(29795);\n }\n });\n }\n newChattingTabUI.ypg = (TestTimeForChatting) newChattingTabUI.iWA.findViewById(newChattingTabUI.yph);\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"ashu::prepareChattingFragment init chattingView, top %s\", Integer.valueOf(statusBarHeight));\n } else {\n C4990ab.m7421w(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"[createChattingView] is not SupportCustomActionBar %s\", Boolean.valueOf(C1436b.m3061Ml()));\n newChattingTabUI.ypg = (TestTimeForChatting) newChattingTabUI.iWA.findViewById(2131821893);\n newChattingTabUI.yph = newChattingTabUI.ypg.getId();\n }\n } else if (newChattingTabUI.ypn.isSupportCustomActionBar()) {\n iArr = new int[2];\n newChattingTabUI.ypg.getLocationInWindow(iArr);\n if (iArr[1] == 0) {\n viewGroup = (ViewGroup) newChattingTabUI.iWA.getWindow().getDecorView();\n statusBarHeight = 0;\n while (true) {\n int i = statusBarHeight;\n if (i >= viewGroup.getChildCount()) {\n break;\n }\n dyW = ((ViewGroup) newChattingTabUI.iWA.getWindow().getDecorView()).getChildAt(i);\n if (dyW instanceof FitSystemWindowLayoutView) {\n newChattingTabUI.iWA.getSupportActionBar().getCustomView().getLocationInWindow(iArr);\n FitSystemWindowLayoutView fitSystemWindowLayoutView2 = (FitSystemWindowLayoutView) dyW;\n ViewGroup viewGroup2 = (ViewGroup) newChattingTabUI.iWA.findViewById(2131820633);\n i = viewGroup2.getPaddingTop();\n int statusBarHeight2 = C5230ak.getStatusBarHeight(newChattingTabUI.iWA);\n Rect rect = new Rect();\n Window window = newChattingTabUI.iWA.getWindow();\n window.getDecorView().getWindowVisibleDisplayFrame(rect);\n int height = window.getDecorView().getHeight();\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"rootLayout2 fitSystemWindows detect: ActionBar's CustomView location[1]:%d, paddingTop:%d getStatusBarHeight():%d, heightFromSysR:%d, rectangle.top:%d, rectangle.height:%d, DecorHeight:%d, cacheInsetsTop:%d\", Integer.valueOf(iArr[1]), Integer.valueOf(i), Integer.valueOf(C5222ae.m7947hA(newChattingTabUI.iWA)), Integer.valueOf(statusBarHeight2), Integer.valueOf(rect.top), Integer.valueOf(rect.height()), Integer.valueOf(height), Integer.valueOf(fitSystemWindowLayoutView2.getCacheInsetsTop()));\n fitSystemWindowLayoutView2.fitSystemWindows(new Rect(0, fitSystemWindowLayoutView2.getCacheInsetsTop(), 0, 0));\n ImageView imageView2 = (ImageView) fitSystemWindowLayoutView2.findViewById(2131820648);\n imageView2.setTag(viewGroup2);\n ViewGroup.LayoutParams layoutParams2 = viewGroup2.getLayoutParams();\n if (layoutParams2 == null || (layoutParams2 instanceof LayoutParams)) {\n imageView2.setLayoutParams(layoutParams2);\n } else {\n C4990ab.m7421w(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"FIX LayoutParams:%s %s\", layoutParams2.toString(), viewGroup2);\n imageView2.setLayoutParams(new LayoutParams(layoutParams2));\n }\n Bitmap magicDrawingCache = newChattingTabUI.getMagicDrawingCache(viewGroup2);\n if (magicDrawingCache != null) {\n imageView2.setImageBitmap(magicDrawingCache);\n viewGroup2.setVisibility(8);\n imageView2.setVisibility(0);\n C4990ab.m7416i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"[prepareChattingFragment] prepareView VISIBLE\");\n } else {\n viewGroup2.setVisibility(0);\n imageView2.setVisibility(8);\n imageView2.setImageDrawable(null);\n C4990ab.m7416i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"[prepareChattingFragment] prepareView GONE\");\n }\n } else {\n boolean z3;\n ImageView imageView3 = (ImageView) dyW.findViewById(2131820648);\n if (imageView3 != null) {\n imageView3.setImageDrawable(null);\n }\n String str = \"MicroMsg.LauncherUI.NewChattingTabUI\";\n String str2 = \"on position %d, rootLayout not found! prepareView is null?%s\";\n Object[] objArr = new Object[2];\n objArr[0] = Integer.valueOf(i);\n if (imageView3 == null) {\n z3 = true;\n } else {\n z3 = false;\n }\n objArr[1] = Boolean.valueOf(z3);\n C4990ab.m7413e(str, str2, objArr);\n statusBarHeight = i + 1;\n }\n }\n }\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"ashu::prepareChattingFragment has chattingView, top %s\", Integer.valueOf(iArr[1]));\n }\n if (intent != null) {\n newChattingTabUI.ypn.getArguments().putAll(C5068w.m7684aM(intent));\n }\n if (z2) {\n newChattingTabUI.mChattingUIProxy.onInit(newChattingTabUI.yph, z);\n newChattingTabUI.ypj = (OnLayoutChangedLinearLayout) newChattingTabUI.ypn.getView().findViewById(2131821521);\n } else {\n newChattingTabUI.mChattingUIProxy.onEnterBegin();\n }\n if (newChattingTabUI.ypn.isSupportNavigationSwipeBack()) {\n newChattingTabUI.ypn.getSwipeBackLayout().setNeedRequestActivityTranslucent(false);\n }\n C4990ab.m7417i(\"MicroMsg.LauncherUI.NewChattingTabUI\", \"ashu::prepareChattingFragment use %dms, needInit %B, Intent %s\", Long.valueOf(System.currentTimeMillis() - currentTimeMillis), Boolean.valueOf(z2), intent);\n AppMethodBeat.m2505o(29823);\n }", "void setupToolBar(String title, boolean showNavigationBtn) {\n setupToolBar(title, showNavigationBtn, new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n// finish();\n onBackPressed();\n }\n });\n }", "private void setupToolbars(){\n\t\ttopBar = new TopBar(0, 0, setup.getFrameWidth()+12, Constants.WINDOW_HEADER_HEIGHT, \n\t\t\t\tConstants.COLOR_HEADER_1, setup);\n\t\t\n\t\tbottomBar = new BottomBar(0, \n\t\t\t\tConstants.WINDOW_HEADER_HEIGHT+(Constants.WINDOW_MAP_MARGIN*2)+Constants.WINDOW_MAP_HEIGHT, \n\t\t\t\tsetup.getFrameWidth()+12, \n\t\t\t\tConstants.WINDOW_HEADER_HEIGHT, \n\t\t\t\tConstants.COLOR_HEADER_1, setup);\n\t\t\n\t\trightBar = new RightBar((Constants.WINDOW_MAP_MARGIN*2)+Constants.WINDOW_MAP_WIDTH, \n\t\t\t\tConstants.WINDOW_HEADER_HEIGHT, \n\t\t\t\tConstants.WINDOW_RIGHT_BAR_WIDTH, \n\t\t\t\tConstants.WINDOW_RIGHT_BAR_HEIGHT, \n\t\t\t\tConstants.COLOR_MAP_LAND, setup);\n\t}", "private void showSnackbarMessage(String message){\n if(view != null){\n Snackbar.make(view, message, Snackbar.LENGTH_SHORT).show();\n }\n }", "private void createToolbars() {\r\n\t\tJToolBar toolBar = new JToolBar(\"Tool bar\");\r\n\t\ttoolBar.add(createBlankDocument);\r\n\t\ttoolBar.add(openDocumentAction);\r\n\t\ttoolBar.add(saveDocumentAction);\r\n\t\ttoolBar.add(saveDocumentAsAction);\r\n\t\ttoolBar.add(closeCurrentTabAction);\r\n\t\t\r\n\t\ttoolBar.addSeparator();\r\n\t\ttoolBar.add(copyAction);\r\n\t\ttoolBar.add(cutAction);\r\n\t\ttoolBar.add(pasteAction);\r\n\t\t\r\n\t\ttoolBar.addSeparator();\r\n\t\ttoolBar.add(getStatsAction);\r\n\t\t\r\n\t\ttoolBar.addSeparator();\r\n\t\ttoolBar.add(exitAction);\r\n\t\t\r\n\t\tgetContentPane().add(toolBar, BorderLayout.PAGE_START);\r\n\t}", "void setupToolBar(String title) {\n setupToolBar(title, new View.OnClickListener() {\n @Override\n public void onClick(View view) {\n onBackPressed();\n }\n });\n }", "private Component createToolBar()\n {\n Component toolbarPanel = null;\n\n mainToolBar = new MainToolBar(this);\n\n boolean chatToolbarVisible\n = ConfigurationUtils.isChatToolbarVisible();\n\n if (OSUtils.IS_MAC)\n {\n UnifiedToolBar macToolbarPanel = new UnifiedToolBar();\n\n MacUtils.makeWindowLeopardStyle(getRootPane());\n\n macToolbarPanel.addComponentToLeft(mainToolBar);\n macToolbarPanel.addComponentToRight(contactPhotoPanel);\n macToolbarPanel.disableBackgroundPainter();\n macToolbarPanel.installWindowDraggerOnWindow(this);\n macToolbarPanel.getComponent()\n .setBorder(BorderFactory.createEmptyBorder(3, 3, 3, 3));\n macToolbarPanel.getComponent().setVisible(chatToolbarVisible);\n\n toolbarPanel = macToolbarPanel.getComponent();\n }\n else\n {\n ToolbarPanel panel = new ToolbarPanel(new BorderLayout());\n\n panel.setBorder(BorderFactory.createEmptyBorder(3, 0, 3, 0));\n panel.add(mainToolBar, BorderLayout.CENTER);\n panel.add(contactPhotoPanel, BorderLayout.EAST);\n panel.setVisible(chatToolbarVisible);\n\n toolbarPanel = panel;\n }\n\n return toolbarPanel;\n }", "public ToolBarManager initTitle(String toolBarTitle){\n return initTitle(toolBarTitle,0xFFFFFFFF);\n }", "public abstract BossBar show();", "protected void fillCoolBar(ICoolBarManager coolBar) {\n\t\tIWorkbenchWindow window = getActionBarConfigurer().getWindowConfigurer().getWindow();\n\t\tIToolBarManager toolbar = new ToolBarManager(SWT.LEFT);\n\t\tcoolBar.add(new ToolBarContributionItem(toolbar, Messages.getString(\"IU.Strings.15\"))); //$NON-NLS-1$\n\t\ttoolbar.add(new GroupMarker(Messages.getString(\"IU.Strings.16\"))); //$NON-NLS-1$\n\n\n\t\t/*IWorkbenchAction open = ActionFactory..create(window);\n\t\topen.setImageDescriptor(Activator.getImageDescriptor(\"icons/charger.png\"));\n\t\ttoolbar.add(open);*/\n\n\t\tIWorkbenchAction save = ActionFactory.SAVE.create(window);\n\t\tsave.setImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.17\"))); //$NON-NLS-1$\n\t\tsave.setDisabledImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.18\"))); //$NON-NLS-1$\n\t\tsave.setHoverImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.19\"))); //$NON-NLS-1$\n\t\tsave.setText(Messages.getString(\"IU.Strings.20\")); //$NON-NLS-1$\n\t\tsave.setToolTipText(Messages.getString(\"IU.Strings.21\")); //$NON-NLS-1$\n\t\ttoolbar.add(save);\n\n\t\tIWorkbenchAction print = ActionFactory.PRINT.create(window);\n\t\tprint.setImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.22\"))); //$NON-NLS-1$\n\t\tprint.setDisabledImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.23\"))); //$NON-NLS-1$\n\t\tprint.setHoverImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.24\"))); //$NON-NLS-1$\n\t\tprint.setText(Messages.getString(\"IU.Strings.25\")); //$NON-NLS-1$\n\t\tprint.setToolTipText(Messages.getString(\"IU.Strings.26\")); //$NON-NLS-1$\n\t\ttoolbar.add(print);\n\n\n\t\ttoolbar.add(new GroupMarker(Messages.getString(\"IU.Strings.27\"))); //$NON-NLS-1$\n\t\ttoolbar.add(new Separator());\n\t\tIWorkbenchAction find = ActionFactory.FIND.create(window);\n\t\tfind.setImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.28\"))); //$NON-NLS-1$\n\t\t//find.setDisabledImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.29\"))); //$NON-NLS-1$\n\t\t//find.setHoverImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.30\"))); //$NON-NLS-1$\n\t\tfind.setText(Messages.getString(\"IU.Strings.31\")); //$NON-NLS-1$\n\t\tfind.setToolTipText(Messages.getString(\"IU.Strings.32\")); //$NON-NLS-1$\n\t\ttoolbar.add(find);\n\n\t\t/*toolbar.add(ActionFactory.COPY.create(window));\n\t\ttoolbar.add(ActionFactory.CUT.create(window));\n\t\ttoolbar.add(ActionFactory.PASTE.create(window));\n\t\ttoolbar.add(new Separator());*/\n\n\t\t//TODO Rrgler le bug d'icon non charger undo / redo entre l'editeur et la console\n\t\t/*IWorkbenchAction undo = ActionFactory.UNDO.create(window);\n\t\tundo.setImageDescriptor(Activator.getImageDescriptor(\"icons/undo.gif\"));\n\t\tundo.setDisabledImageDescriptor(Activator.getImageDescriptor(\"icons/undo.gif\"));\n\t\tundo.setHoverImageDescriptor(Activator.getImageDescriptor(\"icons/undo.gif\"));\n\t\ttoolbar.add(undo);\n\n\t\tIWorkbenchAction redo = ActionFactory.REDO.create(window);\n\t\tredo.setImageDescriptor(Activator.getImageDescriptor(\"icons/redo.gif\"));\n\t\tredo.setDisabledImageDescriptor(Activator.getImageDescriptor(\"icons/redo.gif\"));\n\t\tredo.setHoverImageDescriptor(Activator.getImageDescriptor(\"icons/redo.gif\"));\n\t\ttoolbar.add(redo);*/\n\n\t\t\n\t\t//toolbar.add(ActionFactory.REDO.create(window));*/\n\n\t\t//toolbox2.png\n\t\tToolsBoxAction toolBox = new ToolsBoxAction(window);\n\t\ttoolBox.setImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.33\"))); //$NON-NLS-1$\n\t\ttoolBox.setDisabledImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.34\"))); //$NON-NLS-1$\n\t\ttoolBox.setHoverImageDescriptor(Activator.getImageDescriptor(Messages.getString(\"IU.Strings.35\"))); //$NON-NLS-1$\n\t\ttoolbar.add(toolBox);\n\t\t\n\t\t\n\t\t//action_toolsBox.setMenuCreator(new IMenuCreator(){});\n\t\n\t\t//coolBar.add(new ToolBarContributionItem(toolbar2, \"main2\"));\n\t\t//toolbar2.add(ActionFactory.SHOW_VIEW_MENU.create(window));\n\n\t\t\n\t\tIToolBarManager toolbar2 = new ToolBarManager(SWT.RIGHT | SWT.FLAT | SWT.HORIZONTAL);\n\t\t\n\t\tcoolBar.add(new ToolBarContributionItem(toolbar2, Messages.getString(\"IU.Strings.36\")));\t //$NON-NLS-1$\n\t\ttoolbar2.add(new GroupMarker(Messages.getString(\"IU.Strings.37\"))); //$NON-NLS-1$\n\t\ttoolbar2.add(new GroupMarker(Messages.getString(\"IU.Strings.38\"))); //$NON-NLS-1$\n\t}", "private Composite createTopBar(Composite parent, int span) {\n\t\tComposite c = new Composite(parent, SWT.NO_BACKGROUND);\n\n\t\tGridData cData = new GridData();\n\t\tcData.horizontalSpan = span;\n\t\tcData.horizontalAlignment = GridData.FILL;\n\t\tc.setLayoutData(cData);\n\n\t\tGridLayout layout = new GridLayout();\n\t\tlayout.numColumns = 3;\n\t\tc.setLayout(layout);\n\n\n\t\tLabel weightLabel = new Label(c, SWT.LEFT);\n\t\tGridData weightData = new GridData();\n\t\tweightData.grabExcessHorizontalSpace = true;\n\t\tweightLabel.setLayoutData(weightData);\n\t\tweightLabel.setText(Resources.getMessage(\"RiskWizard.19\"));\n\t\tFontDescriptor boldDescriptor = FontDescriptor.createFrom(weightLabel.getFont()).setStyle(SWT.BOLD);\n\t\tFont boldFont = boldDescriptor.createFont(weightLabel.getDisplay());\n\t\tweightLabel.setFont(boldFont);\n\t\tfileLabel = weightLabel;\n\t\t\n\t\tfinal Combo visualizationDropDown = new Combo(c, SWT.DROP_DOWN | SWT.READ_ONLY | SWT.BORDER);\n\t\tString monitorTitle = Resources.getMessage(\"RiskWizard.12\");\n\t\tString stacksTitle = Resources.getMessage(\"RiskWizard.13\");\n\t\tvisualizationDropDown.add(monitorTitle);\n\t\tvisualizationDropDown.add(stacksTitle);\n\t\tvisualizationDropDown.setText(monitorTitle);\n\t\tvisualizationDropDown.addSelectionListener(new SelectionAdapter() {\n\t\t\t@Override\n\t\t\tpublic void widgetSelected(SelectionEvent e) {\n\t\t\t\tString selected = visualizationDropDown.getText(); \n\t\t\t\tif(selected.equals(stacksTitle)) {\n\t\t\t\t\t//System.out.println(\"Select Stacks\");\n\t\t\t\t\tshowStacksVisualization();\n\t\t\t\t} else if(selected.equals(monitorTitle)) {\n\t\t\t\t\t//System.out.println(\"Select Monitor\");\n\t\t\t\t\tshowMonitorVisualization();\n\t\t\t\t}\n\t\t\t}\n\t\t});\n\n\t\tLabel separator = new Label(c, SWT.SEPARATOR | SWT.HORIZONTAL);\n\t\tGridData sepData = new GridData();\n\t\tsepData.horizontalSpan = layout.numColumns;\n\t\tsepData.grabExcessHorizontalSpace = true;\n\t\tsepData.horizontalAlignment = GridData.FILL;\n\t\tseparator.setLayoutData(sepData);\n\n\t\ttopBar = c;\n\t\treturn c;\n\t}", "void inittoolbar() {\n toolbar = (Toolbar) findViewById(R.id.toolbar);\r\n setSupportActionBar(toolbar);\r\n if (getSupportActionBar() != null) {\r\n getSupportActionBar().setDisplayShowTitleEnabled(false);\r\n }\r\n TextView mTitle = (TextView) toolbar.findViewById(R.id.toolbar_title);\r\n ImageView back = (ImageView) toolbar.findViewById(R.id.back);\r\n mTitle.setText(getResources().getString(R.string.scanQr));\r\n\r\n back.setOnClickListener(new View.OnClickListener() {\r\n @Override\r\n public void onClick(View v) {\r\n onBackPressed();\r\n }\r\n });\r\n }", "private void defineToolBar() {\r\n //ARREGLO CON LOS BOTONES ORDENADOS POR POSICION\r\n tools = new ImageView[]{im_tool1,im_tool2,im_tool3,im_tool4,im_tool5,im_tool6,im_tool7,im_tool8,im_tool9,im_tool10,im_tool11,im_tool12}; \r\n //CARGA DE LA BD LA CONFIGURACION DE USUARIO PARA LA PANTALLA\r\n toolsConfig = Ln.getInstance().loadToolBar();\r\n // arreglo con cada etiqueta, ordenado por boton\r\n tooltips = new String[]{\r\n \"Nueva \" + ScreenName + \" \",\r\n \"Editar \" + ScreenName + \" \",\r\n \"Guardar \" + ScreenName + \" \",\r\n \"Cambiar Status de \" + ScreenName + \" \",\r\n \"Imprimir \" + ScreenName + \" \",\r\n \"Cancelar \",\r\n \"Sin Asignar \",\r\n \"Faltante en \" + ScreenName + \" \",\r\n \"Devolución en \" + ScreenName + \" \",\r\n \"Sin Asignar\",\r\n \"Sin Asignar\",\r\n \"Buscar \" + ScreenName + \" \"\r\n };\r\n //se asigna la etiqueta a su respectivo boton\r\n for (int i = 0; i < tools.length; i++) { \r\n Tooltip tip_tool = new Tooltip(tooltips[i]);\r\n Tooltip.install(tools[i], tip_tool);\r\n }\r\n \r\n im_tool7.setVisible(false);\r\n im_tool8.setVisible(false);\r\n im_tool9.setVisible(false);\r\n im_tool10.setVisible(false);\r\n im_tool11.setVisible(false);\r\n }", "@SuppressLint(\"StringFormatMatches\")\n private String createToast(double grade) {\n String message;\n Resources res = getResources();\n message = res.getString(R.string.toast_message, grade);\n return message;\n }", "public void initToolbar() {\r\n\r\n ((HomeActivity) getActivity()).setUpToolbar(getString(R.string.help), false, true, false,false);\r\n\r\n\r\n }", "public void showToast(String text)\n {\n Text icon = GlyphsDude.createIcon(FontAwesomeIconName.CHECK_CIRCLE,\"1.5em\");\n icon.setFill(Color.WHITE);\n Label l = new Label(text) ;\n l.setTextFill(Color.WHITE);\n l.setGraphic(icon);\n snackbar = new JFXSnackbar(PrinciplePane);\n snackbar.enqueue( new JFXSnackbar.SnackbarEvent(l));\n }", "private void setupSystemUI() {\r\n toolbar.animate().translationY(Measure.getStatusBarHeight(getResources())).setInterpolator(new DecelerateInterpolator())\r\n .setDuration(0).start();\r\n getWindow().getDecorView().setSystemUiVisibility(\r\n View.SYSTEM_UI_FLAG_LAYOUT_STABLE\r\n | View.SYSTEM_UI_FLAG_LAYOUT_HIDE_NAVIGATION\r\n | View.SYSTEM_UI_FLAG_LAYOUT_FULLSCREEN);\r\n }", "private void showBars() {\n if (!mIsActive || mShowBars) {\n return;\n }\n mShowBars = true;\n mOrientationManager.unlockOrientation();\n showToolBar(true);\n showStatusBar();\n // mActionBar.show();\n //mActivity.getGLRoot().setLightsOutMode(false);\n refreshHidingMessage();\n refreshBottomControlsWhenReady();\n }", "@Override\n\tprotected void onConfigrationTitleBar() {\n\t\tsetTitleBarTitleText(R.string.shujuxiazai);\n setTitleBarLeftImageButtonImageResource(R.drawable.title_back);\n\t}", "private void setActionBar() {\n ActionBar mActionBar = getSupportActionBar();\n mActionBar.setDisplayOptions(ActionBar.DISPLAY_SHOW_CUSTOM);\n mActionBar.setCustomView(R.layout.actionbar_design);\n\n\n View mCustomView = mActionBar.getCustomView();\n ImageView image_drawer = (ImageView) mCustomView.findViewById(R.id.image_drawer);\n ImageView img_btllogo = (ImageView) mCustomView.findViewById(R.id.img_btllogo);\n ImageView img_home = (ImageView) mCustomView.findViewById(R.id.img_home);\n ImageView img_category = (ImageView) mCustomView.findViewById(R.id.img_category);\n ImageView img_notification = (ImageView) mCustomView.findViewById(R.id.img_notification);\n ImageView img_cart = (ImageView) mCustomView.findViewById(R.id.img_cart);\n FrameLayout frame = (FrameLayout)mCustomView.findViewById(R.id.unread);\n frame.setVisibility(View.VISIBLE);\n /* TextView txt = (TextView)mCustomView.findViewById(R.id.menu_message_tv);\n db = new DatabaseHandler(User_Profile.this);\n bean_cart = db.Get_Product_Cart();\n db.close();\n txt.setText(bean_cart.size()+\"\");*/\n image_drawer.setImageResource(R.drawable.ic_action_btl_back);\n img_notification.setVisibility(View.GONE);\n img_cart.setVisibility(View.VISIBLE);\n\n\n\n TextView txt = (TextView)mCustomView.findViewById(R.id.menu_message_tv);\n img_notification.setVisibility(View.GONE);\n app = new AppPrefs(Saved_Address.this);\n String qun =app.getCart_QTy();\n\n /* setRefershData();\n\n if(user_data.size() != 0){\n for (int i = 0; i < user_data.size(); i++) {\n\n owner_id =user_data.get(i).getUser_id().toString();\n\n role_id=user_data.get(i).getUser_type().toString();\n\n if (role_id.equalsIgnoreCase(\"6\") ) {\n\n app = new AppPrefs(this);\n role_id = app.getSubSalesId().toString();\n u_id = app.getSalesPersonId().toString();\n }else if(role_id.equalsIgnoreCase(\"7\")){\n app = new AppPrefs(this);\n role_id = app.getSubSalesId().toString();\n u_id = app.getSalesPersonId().toString();\n //Log.e(\"IDIDD\",\"\"+app.getSalesPersonId().toString());\n }else{\n u_id=owner_id;\n }\n\n\n }\n\n List<NameValuePair> para=new ArrayList<NameValuePair>();\n\n para.add(new BasicNameValuePair(\"owner_id\", owner_id));\n para.add(new BasicNameValuePair(\"user_id\",u_id));\n\n\n String json=GetCartByQty(para);\n\n try {\n\n\n //System.out.println(json);\n\n if (json==null\n || (json.equalsIgnoreCase(\"\"))) {\n *//*Toast.makeText(Business_Registration.this, \"SERVER ERRER\",\n Toast.LENGTH_SHORT).show();*//*\n Globals.CustomToast(this, \"SERVER ERRER\", getLayoutInflater());\n // loadingView.dismiss();\n\n } else {\n JSONObject jObj = new JSONObject(json);\n\n String date = jObj.getString(\"status\");\n\n if (date.equalsIgnoreCase(\"false\")) {\n\n app = new AppPrefs(Saved_Address.this);\n app.setCart_QTy(\"0\");\n\n // loadingView.dismiss();\n } else {\n\n\n int qu = jObj.getInt(\"data\");\n app = new AppPrefs(Saved_Address.this);\n app.setCart_QTy(\"\"+qu);\n\n\n }\n\n }\n }catch(Exception j){\n j.printStackTrace();\n //Log.e(\"json exce\",j.getMessage());\n }\n\n }else{\n app = new AppPrefs(Saved_Address.this);\n app.setCart_QTy(\"\");\n }*/\n\n app = new AppPrefs(Saved_Address.this);\n String qu1 = app.getCart_QTy();\n if(qu1.equalsIgnoreCase(\"0\") || qu1.equalsIgnoreCase(\"\")){\n txt.setVisibility(View.GONE);\n txt.setText(\"\");\n }else{\n if(Integer.parseInt(qu1) > 999){\n txt.setText(\"999+\");\n txt.setVisibility(View.VISIBLE);\n }else {\n txt.setText(qu1 + \"\");\n txt.setVisibility(View.VISIBLE);\n }\n }\n\n image_drawer.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n Intent i = new Intent(Saved_Address.this, User_Profile.class);\n i.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP);\n startActivity(i);\n }\n });\n img_home.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n Intent i = new Intent(Saved_Address.this,MainPage_drawer.class);\n i.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP);\n startActivity(i);\n }\n });\n img_cart.setOnClickListener(new View.OnClickListener() {\n @Override\n public void onClick(View v) {\n app = new AppPrefs(Saved_Address.this);\n app.setUser_notification(\"Saved_Address\");\n Intent i = new Intent(Saved_Address.this, BTL_Cart.class);\n i.addFlags(Intent.FLAG_ACTIVITY_CLEAR_TOP);\n startActivity(i);\n }\n });\n\n\n mActionBar.setCustomView(mCustomView);\n mActionBar.setDisplayShowCustomEnabled(true);\n }", "private BrowserToolbar() {\n\t\tinitComponents();\n\t}", "String getToolbarWarnings() throws GWTJahiaServiceException;", "private void m119424c() {\n View view = new View(getContext());\n view.setLayoutParams(new FrameLayout.LayoutParams(-1, DisplayUtils.m87172c(getContext())));\n view.setBackgroundColor(C17345i.m87160a(ContextCompat.getColor(getContext(), R.color.BK01), 0.2f));\n ViewGroup viewGroup = (ViewGroup) getView();\n if (f85662a || viewGroup != null) {\n viewGroup.addView(view);\n ViewGroup.MarginLayoutParams marginLayoutParams = (ViewGroup.MarginLayoutParams) this.mSystemBar.getLayoutParams();\n marginLayoutParams.topMargin = DisplayUtils.m87171b(getContext(), 36.0f) - DisplayUtils.m87172c(getContext());\n this.mSystemBar.setLayoutParams(marginLayoutParams);\n m119425d();\n return;\n }\n throw new AssertionError();\n }", "public SwingStatusBar() {\n super();\n \n setBorder(BorderFactory.createEmptyBorder(0, SMALL_BORDER, SMALL_BORDER,\n SMALL_BORDER));\n \n messageLabel = new JLabel(DEFAULT_MESSAGE);\n iconLabel = new JLabel(DEFAULT_ICON);\n \n messageLabel.setBorder(BorderFactory.createEtchedBorder());\n iconLabel.setBorder(BorderFactory.createEtchedBorder());\n \n messageLabel.addMouseListener(this);\n iconLabel.addMouseListener(this);\n ErrorManager.getErrorManager().addErrorListener(this);\n clearError();\n \n setLayout(new SpringLayout());\n \n add(messageLabel);\n add(iconLabel);\n \n setPreferredSize(new Dimension(Short.MAX_VALUE, 25));\n setMaximumSize(new Dimension(Short.MAX_VALUE, 25));\n \n layoutBar();\n }", "private void setActionBar() {\n headView.setText(\"消息中心\");\n headView.setGobackVisible();\n headView.setRightGone();\n // headView.setRightResource();\n }", "public StatusBar() {\n\t\tthis(DEFAULT_STATUS_MESSAGE, true, 1, 1, true);\n\t}", "public void createStatusBar(JPanel bar) {\n bar.setPreferredSize(new Dimension(getWidth(), 25));\n bar.setBackground(Color.LIGHT_GRAY);\n\n // add into container\n bar.add(paintModule.sizeLabel);\n bar.add(paintModule.coordinate);\n\n }", "private void createRequestToolbar ( ExpandableComposite parent ) {\n \t\trawRequestAction = new ShowRawRequestAction();\n \t\trawRequestAction.setChecked(true);\n \t\ttreeAction = new ShowInTreeAction();\n \n \t\tToolBarManager toolBarManager = new ToolBarManager(SWT.FLAT);\n \t\tToolBar toolbar = toolBarManager.createControl(parent);\n \n \t\ttoolBarManager.add(rawRequestAction);\n \t\ttoolBarManager.add(treeAction);\n \n \t\ttoolBarManager.update(true);\n \n \t\tparent.setTextClient(toolbar);\n \t}", "public StatusBar() {\n\t\tsuper();\n\t}", "private void createLabels() {\n\n // Add status labels\n infoItem = new ToolItem(toolbar, SWT.SEPARATOR);\n infoComposite = new Composite(toolbar, SWT.NONE);\n infoItem.setControl(infoComposite);\n infoComposite.setLayout(null);\n\n labelAttribute = new Label(infoComposite, SWT.SINGLE | SWT.READ_ONLY);\n labelAttribute.setText(Resources.getMessage(\"MainToolBar.33\")); //$NON-NLS-1$\n labelAttribute.pack(); \n labelTransformations = new Label(infoComposite, SWT.SINGLE | SWT.READ_ONLY);\n labelTransformations.setText(Resources.getMessage(\"MainToolBar.33\")); //$NON-NLS-1$\n labelTransformations.pack();\n labelSelected = new Label(infoComposite, SWT.SINGLE | SWT.READ_ONLY);\n labelSelected.setText(Resources.getMessage(\"MainToolBar.31\")); //$NON-NLS-1$\n labelSelected.pack();\n labelApplied = new Label(infoComposite, SWT.SINGLE | SWT.READ_ONLY);\n labelApplied.setText(Resources.getMessage(\"MainToolBar.32\")); //$NON-NLS-1$\n labelApplied.pack();\n \n // Copy info to clip board on right-click\n Menu menu = new Menu(toolbar);\n MenuItem itemCopy = new MenuItem(menu, SWT.NONE);\n itemCopy.setText(Resources.getMessage(\"MainToolBar.42\")); //$NON-NLS-1$\n itemCopy.addSelectionListener(new SelectionAdapter(){\n public void widgetSelected(SelectionEvent arg0) {\n if (tooltip != null) {\n Clipboard clipboard = new Clipboard(toolbar.getDisplay());\n TextTransfer textTransfer = TextTransfer.getInstance();\n clipboard.setContents(new String[]{tooltip}, \n new Transfer[]{textTransfer});\n clipboard.dispose();\n }\n }\n });\n labelSelected.setMenu(menu);\n labelApplied.setMenu(menu);\n labelTransformations.setMenu(menu);\n \n // Add listener for layout\n toolbar.addControlListener(new ControlAdapter() {\n @Override\n public void controlResized(final ControlEvent arg0) {\n layout();\n }\n });\n }", "protected void toastshow1() {\n \n\t\tToast toast=Toast.makeText(this, \"image and text\", Toast.LENGTH_LONG);\n\t\t\n\t\tLinearLayout linearLayout=new LinearLayout(this);\n\t\tlinearLayout.setOrientation(LinearLayout.VERTICAL);\n\t\tImageView imageView=new ImageView(this);\n\t\timageView.setImageResource(R.drawable.icon);\n\t\tButton button=new Button(this);\n\t\tbutton.setText(\"progress over\");\n\t\tView toastView=toast.getView();\n\t\tlinearLayout.addView(imageView);\n\t\tlinearLayout.addView(button);\n\t\tlinearLayout.addView(toastView);\n\t\t\n\t\ttoast.setView(linearLayout);\n\t\ttoast.show();\n\t\t\n\t}", "public static void showRedSnackbar(String message, Activity activity, int snackbarDuration) {\n snackbar = Snackbar.make(activity.findViewById(android.R.id.content), message, snackbarDuration);\n View snackbarView = snackbar.getView();\n snackbarView.setBackgroundColor(Color.parseColor(RED));\n\n TextView snackbarText = snackbarView.findViewById(com.google.android.material.R.id.snackbar_text);\n snackbarText.setCompoundDrawablesWithIntrinsicBounds(R.drawable.ic_vector_cross, 0, 0, 0);\n snackbarText.setCompoundDrawablePadding(ICON_PADDING_SNACKBAR);\n snackbarText.setGravity(Gravity.CENTER);\n\n FrameLayout.LayoutParams params = (FrameLayout.LayoutParams)snackbarView.getLayoutParams();\n params.width = FrameLayout.LayoutParams.MATCH_PARENT;\n snackbarView.setLayoutParams(params);\n\n snackbar.show();\n }", "public ToolBarManager initSubTitle(int toolBarSubTitleResId){\n mToolbar.setTitle(mContext.getResources().getString(toolBarSubTitleResId));\n return instance;\n }", "public void initToolbar(){\n Toolbar toolbar = (Toolbar) findViewById(R.id.toolbar);\n setSupportActionBar(toolbar);\n if(getSupportActionBar()!=null) {\n getSupportActionBar().setTitle(\"\");\n }\n getSupportActionBar().setHomeAsUpIndicator(R.drawable.ic_launcher_white);\n getSupportActionBar().setDisplayHomeAsUpEnabled(true);\n if (Build.VERSION.SDK_INT >= Build.VERSION_CODES.LOLLIPOP) {\n Window window = getWindow();\n window.addFlags(WindowManager.LayoutParams.FLAG_DRAWS_SYSTEM_BAR_BACKGROUNDS);\n window.setStatusBarColor(ContextCompat.getColor(this, R.color.colorPrimaryDarkest));\n }\n }", "public MessageBarHandler(MainCont controller){\n super(controller);\n this.app = controller.getApp();\n jDex = app.getJDex();\n messageLabel = controller.messageLabel;\n }", "public void enableBar() {\n\t\t// enable listener for alerts button\n\t\t// alerts button\n\t\tthis.alertsButton = (Button) this.findViewById(R.id.alertsButton);\n\t\tupdateAlertCount();\n\t\tthis.alertsButton.setOnClickListener(new OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(View view) {\n\t\t\t\t// featureNotEnabledMsg();\n\t\t\t\t// change layout to alerts layout\n\t\t\t\t// Intent myIntent = new Intent(v.getContext(),\n\t\t\t\t// AlertsActivity.class);\n\t\t\t\t// startActivityForResult(myIntent, 0);\n\t\t\t\tIntent myIntent = new Intent(view.getContext(),\n\t\t\t\t\t\tAlertsActivity.class);\n\t\t\t\t// startActivityForResult(myIntent, 0);\n\t\t\t\tstartActivity(myIntent);\n\t\t\t}\n\t\t});\n\t\t// FOR TEST\n\t\t// clicking bar will make a fake alert\n\t\tthis.barButton = (Button) this.findViewById(R.id.mainBar);\n\t\tupdateAlertCount();\n\t\tthis.barButton.setOnClickListener(new OnClickListener() {\n\t\t\t@Override\n\t\t\tpublic void onClick(View view) {\n\t\t\t\t// FOR TEST - create fake alert!!!\n\t\t\t\taddAlert(\"Fake Test Alert\");\n\t\t\t}\n\t\t});\n\t\t// disable button if alerts is disabled\n\t\tif (CapstoneControlActivity.testItemsDisabled) {\n\t\t\tbarButton.setEnabled(false);\n\t\t}\n\t\t// set up for thread that will search for alerts\n\t\tfinal Button alertsButton = (Button) this\n\t\t\t\t.findViewById(R.id.alertsButton);\n\t\tfinal Handler handler = new Handler();\n\t\tfinal Runnable updateRunner = new Runnable() {\n\t\t\tpublic void run() {\n\t\t\t\t// we are now in the event handling so to speak, update the gui\n\t\t\t\tif (alertsList.isEmpty()) {\n\t\t\t\t\t// set 0\n\t\t\t\t\talertsButton.setText(\"0\");\n\t\t\t\t} else {\n\t\t\t\t\t// set to the number of alerts\n\t\t\t\t\tString alertSize = Integer.toString(alertsList.size());\n\t\t\t\t\talertsButton.setText(alertSize);\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\t}", "void setToolbar(int toolbarTemp) {\n\n }", "private void showRemoveUndoSnackbar(final BluetoothInfo BluetoothInfo) {\n removeBluetoothFromListView(BluetoothInfo);\n\n // Show snackbar with undo option\n String text = String.format(getString(R.string.something_deleted),\n getString(R.string.bluetooth));\n\n UsefulBits.showSnackbarWithAction(this, coordinatorLayout, text, Snackbar.LENGTH_SHORT, new Snackbar.Callback() {\n @Override\n public void onDismissed(Snackbar snackbar, int event) {\n super.onDismissed(snackbar, event);\n switch (event) {\n case Snackbar.Callback.DISMISS_EVENT_TIMEOUT:\n case Snackbar.Callback.DISMISS_EVENT_CONSECUTIVE:\n case Snackbar.Callback.DISMISS_EVENT_MANUAL:\n case Snackbar.Callback.DISMISS_EVENT_SWIPE:\n case Snackbar.Callback.DISMISS_EVENT_ACTION:\n removeBluetoothFromListView(BluetoothInfo);\n break;\n }\n }\n }, v -> {\n updateBluetooth(BluetoothInfo);//undo\n }, this.getString(R.string.undo));\n }", "@Override\n public void onFailure(int statusCode, Header[] headers, byte[] responseBody, Throwable error) {\n Snackbar snackbar = Snackbar.make(findViewById(android.R.id.content), \"Error occurred! Please log out and log in again to upload the interview.\" + \"\\n\" + \"Note: Do not log out if you want to resume the offline interview process.\", Snackbar.LENGTH_LONG);\n View snackbarView = snackbar.getView();\n TextView tv = (TextView) snackbarView.findViewById(android.support.design.R.id.snackbar_text);\n tv.setTextColor(getResources().getColor(R.color.dashboard_count_color));\n tv.setMaxLines(5);\n //tv.setTextSize(17);\n //tv.setGravity(0);\n //snackbarView.setBackgroundColor(getResources().getColor(R.color.newblack));\n snackbar.show();\n }", "private static Widget getLoadingMessage(String msg){\n HorizontalPanel hp = new HorizontalPanel();\n\n\n if(msg == null || msg.isEmpty()){\n hp.add(new Image(DisclosureImages.INSTANCE.getLoadingImage()));\n hp.add(new HTMLPanel(\"Please wait while the data for selection is retrieved...\"));\n }else{\n hp.add(new Image(ReactomeImages.INSTANCE.exclamation()));\n hp.add(new HTMLPanel(msg));\n }\n\n hp.setSpacing(5);\n\n return hp;\n }", "private Component buildToolBar() {\r\n DToolBar toolBar = new DToolBar();\r\n// toolBar.applyComponentOrientation(ComponentOrientation.RIGHT_TO_LEFT);\r\n toolBar.setFloatable(true);\r\n toolBar.putClientProperty(\"JToolBar.isRollover\", Boolean.TRUE);\r\n // Swing\r\n toolBar.putClientProperty(\r\n Options.HEADER_STYLE_KEY,\r\n settings.getToolBarHeaderStyle());\r\n toolBar.putClientProperty(\r\n PlasticLookAndFeel.BORDER_STYLE_KEY,\r\n settings.getToolBarPlasticBorderStyle());\r\n toolBar.putClientProperty(\r\n WindowsLookAndFeel.BORDER_STYLE_KEY,\r\n settings.getToolBarWindowsBorderStyle());\r\n toolBar.putClientProperty(\r\n PlasticLookAndFeel.IS_3D_KEY,\r\n settings.getToolBar3DHint());\r\n\r\n AbstractButton button;\r\n/*\r\n toolBar.add(createToolBarButton(\"backward.gif\", \"Back\"));\r\n button = createToolBarButton(\"forward.gif\", \"Next\");\r\n button.setEnabled(false);\r\n toolBar.add(button);*/\r\n \r\n button = createToolBarButton(\"home.gif\", ResourceUtil.getString(\"HOME\"));\r\n toolBar.add(button);\r\n button.addActionListener(this);\r\n button.setActionCommand(\"home\");\r\n// toolBar.addSeparator();\r\n \r\n button = createToolBarButton(\"preference16.gif\", ResourceUtil.getString(\"PREFERENCES\"));\r\n toolBar.add(button);\r\n button.setRolloverIcon(readImageIcon(\"preference16_over.gif\"));\r\n button.addActionListener(this);\r\n button.setActionCommand(\"Preferences\");\r\n toolBar.addSeparator();\r\n\r\n button = createToolBarButton(\"new16.gif\", ResourceUtil.getString(\"NEW\"));\r\n button.setActionCommand(\"new\");\r\n button.addActionListener(this);\r\n toolBar.add(button);\r\n \r\n button = createToolBarButton(\"save_edit.gif\", ResourceUtil.getString(\"SAVE\"));\r\n button.setActionCommand(\"save\");\r\n button.addActionListener(this);\r\n toolBar.add(button);\r\n \r\n button = createToolBarButton(\"delete16.gif\", ResourceUtil.getString(\"DELETE\"));\r\n button.setActionCommand(\"delete\");\r\n button.addActionListener(this);\r\n toolBar.add(button);\r\n \r\n button = createToolBarButton(\"print.gif\", ResourceUtil.getString(\"PRINT\"));\r\n button.setActionCommand(\"print\");\r\n button.addActionListener(this);\r\n toolBar.add(button);\r\n/* \r\n toolBar.add(createToolBarButton(\"print.gif\", \"Print\"));\r\n toolBar.add(createToolBarButton(\"refresh.gif\", \"Update\"));\r\n toolBar.addSeparator();\r\n\r\n ButtonGroup group = new ButtonGroup();\r\n button = createToolBarRadioButton(\"pie_mode.png\", \"Pie Chart\");\r\n button.setSelectedIcon(readImageIcon(\"pie_mode_selected.gif\"));\r\n group.add(button);\r\n button.setSelected(true);\r\n toolBar.add(button);\r\n\r\n button = createToolBarRadioButton(\"bar_mode.png\", \"Bar Chart\");\r\n button.setSelectedIcon(readImageIcon(\"bar_mode_selected.gif\"));\r\n group.add(button);\r\n toolBar.add(button);\r\n\r\n button = createToolBarRadioButton(\"table_mode.png\", \"Table\");\r\n button.setSelectedIcon(readImageIcon(\"table_mode_selected.gif\"));\r\n group.add(button);\r\n toolBar.add(button);\r\n toolBar.addSeparator();\r\n\r\n button = createToolBarButton(\"help.gif\", \"Open Help\");\r\n button.addActionListener(createHelpActionListener());\r\n toolBar.add(button);*/\r\n\r\n return toolBar;\r\n }", "public ToolBarManager initTitle(String toolBarTitle,int start,int top,int end,int bottom){\n if(toolBarTitle!=null){\n mToolbar.setTitle(toolBarTitle);\n mToolbar.setTitleMargin(start,top,end,bottom);\n }\n return instance;\n }", "private void updateActionBar() {\n\t\tif (!(getContext() instanceof AppCompatActivity)) {\n\t\t\treturn;\n\t\t}\n\n\t\ttoolbar.setSubtitle(R.string.cvv_enter_security_code);\n\t}", "private void initToolBar(){\n toolbar = (Toolbar) findViewById(R.id.toolbar);\n setSupportActionBar(toolbar);\n }", "void showForbiddenErrorSnackbar();", "public ToolBarManager initTitle(String toolBarTitle, int color,int start,int top,int end,int bottom){\n if(toolBarTitle!=null){\n mToolbar.setTitle(toolBarTitle);\n mToolbar.setTitleTextColor(color);\n mToolbar.setTitleMargin(start,top,end,bottom);\n }\n return instance;\n }", "public void showSnackBar(final View view, final String message) {\n Snackbar.make(view, message, Snackbar.LENGTH_SHORT).show();\n }", "public void showSnack(boolean isConnected) {\n String message;\n int color;\n if (isConnected) {\n message = \"Good! Connected to Internet\";\n color = Color.WHITE;\n getUserLocation();\n } else {\n message = \"Sorry! Not connected to internet\";\n color = Color.RED;\n }\n\n Snackbar snackbar = Snackbar.make(activity.findViewById(android.R.id.content), message, Snackbar.LENGTH_LONG);\n\n View sbView = snackbar.getView();\n// TextView textView = (TextView) sbView.findViewById(a);\n// textView.setTextColor(color);\n snackbar.show();\n }", "private void createToolbar() {\n\t\ttoolbarPanel = new JPanel(new FlowLayout(FlowLayout.LEFT));\n\n\t\tString iconsDir = \"icons/\";\n\n\t\tfileToolbar = new JToolBar();\n\t\tfileToolbar.setName(\"File\");\n\n\t\t// Componentes da barra de ferramentas de arquivo\n\t\tIcon newFileIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"new.png\"));\n\t\tnewFileButton = new JButton(newFileIcon);\n\t\tnewFileButton.setToolTipText(\"Novo arquivo\");\n\n\t\tIcon openFileIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"open.png\"));\n\t\topenFileButton = new JButton(openFileIcon);\n\t\topenFileButton.setToolTipText(\"Abrir arquivo\");\n\t\topenFileButton.addActionListener(new OpenFileHandler());\n\n\t\tIcon saveFileIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"save.png\"));\n\t\tsaveFileButton = new JButton(saveFileIcon);\n\t\tsaveFileButton.setToolTipText(\"Salvar arquivo\");\n\n\t\t// fileToolbar.add(newFileButton);\n\t\tfileToolbar.add(openFileButton);\n\t\t// fileToolbar.add(saveFileButton);\n\n\t\t// Componentes da barra de ferramentas de rede\n\t\tnetworkComponentsToolbar = new JToolBar();\n\t\tnetworkComponentsToolbar.setName(\"Network components\");\n\n\t\tIcon newPlaceIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"circle_stroked.png\"));\n\t\taddPlaceButton = new JButton(newPlaceIcon);\n\t\taddPlaceButton.setToolTipText(\"Adicionar lugar\");\n\n\t\tIcon newTransitionIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"pipe.png\"));\n\t\taddTransitionButton = new JButton(newTransitionIcon);\n\t\taddTransitionButton.setToolTipText(\"Adicionar transição\");\n\n\t\tIcon newEdgeIcon = new ImageIcon(getClass().getClassLoader().getResource(iconsDir + \"arrow_alt_right.png\"));\n\t\taddEdgeButton = new JButton(newEdgeIcon);\n\t\taddEdgeButton.setToolTipText(\"Adicionar aresta\");\n\n\t\tnetworkComponentsToolbar.add(addPlaceButton);\n\t\tnetworkComponentsToolbar.add(addTransitionButton);\n\t\tnetworkComponentsToolbar.add(addEdgeButton);\n\n\t\ttoolbarPanel.add(fileToolbar);\n\t\t// toolbarPanel.add(networkComponentsToolbar);\n\n\t\tthis.add(toolbarPanel, BorderLayout.NORTH);\n\t}", "@Override\n\tprotected void initTopbar(){\n\t\tsuper.initTopbar();\n\t\tTextView textView = new TextView(mContext);\n\t\ttextView.setText(\"宝贝\");\n\t\ttextView.setTextSize(22);\n\t\ttextView.setTextColor(Color.BLACK);\n\t\tTopBar topBar = new TopBar(this,false, textView, null);\n\t\ttopBar.bind();\n\t}", "public void prepareTitleView(int i) {\n int i2;\n setBackground(getResources().getDrawable(R.drawable.fs_gesture_back_bg, (Resources.Theme) null));\n int i3 = R.string.how_to_use_app_quick;\n switch (i) {\n case 0:\n i2 = R.string.fs_gesture_left_back_ready_summary;\n break;\n case 1:\n i2 = R.string.fs_gesture_right_back_ready_summary;\n break;\n case 2:\n i3 = R.string.how_to_back_home;\n i2 = R.string.fs_gesture_back_home_summary;\n break;\n case 3:\n i3 = R.string.how_to_switch_recents;\n i2 = R.string.fs_gesture_switch_recents_summary;\n break;\n case 4:\n i3 = R.string.how_to_use_drawer;\n i2 = R.string.how_to_use_drawer_summary;\n break;\n case 5:\n i2 = R.string.how_to_use_app_quick_summary;\n break;\n case 6:\n i2 = R.string.how_to_use_app_quick_hide_line_summary;\n break;\n default:\n i2 = 0;\n i3 = 0;\n break;\n }\n i3 = R.string.fs_gesture_back_ready_title;\n TextView textView = this.mTitleView;\n if (textView != null && this.mSummaryView != null) {\n textView.setText(i3);\n this.mSummaryView.setText(i2);\n this.mTitleView.setVisibility(0);\n }\n }", "private void autoSetBarSize() {\n float statusBarHeight = Utils.getStatusBarHeight(ModifyPassActivity.this);\n mStatusView = findViewById(R.id.view_modify_status_bar);\n LinearLayout.LayoutParams Params1 = new LinearLayout.LayoutParams(\n ViewGroup.LayoutParams.MATCH_PARENT, (int) statusBarHeight);\n mStatusView.setLayoutParams(Params1);\n }" ]
[ "0.6895972", "0.683639", "0.6465948", "0.64314544", "0.61043954", "0.60274833", "0.5983804", "0.59502757", "0.59219414", "0.58640033", "0.5742379", "0.5725801", "0.5716366", "0.5674249", "0.567381", "0.56690437", "0.56141865", "0.5564288", "0.55134314", "0.548876", "0.544671", "0.5426903", "0.54237854", "0.53838605", "0.5360288", "0.5358195", "0.5346657", "0.53251916", "0.5323646", "0.53180075", "0.53061575", "0.53061575", "0.53061575", "0.53061575", "0.53061575", "0.53061575", "0.53061575", "0.53015715", "0.5279703", "0.5271714", "0.5268944", "0.52553684", "0.5230982", "0.5224755", "0.52203315", "0.5205699", "0.5204359", "0.52031374", "0.5195115", "0.5177326", "0.5176361", "0.5170799", "0.5167491", "0.51569265", "0.5153582", "0.5136153", "0.51312315", "0.51298124", "0.5128594", "0.51215875", "0.5121175", "0.5118606", "0.5117113", "0.51085585", "0.5106739", "0.51061946", "0.5103099", "0.50982696", "0.5095412", "0.507462", "0.5073852", "0.50730056", "0.50575256", "0.50556195", "0.50537837", "0.50367737", "0.50289", "0.50275683", "0.50187135", "0.5012573", "0.50099415", "0.5002425", "0.49982545", "0.4997831", "0.49977013", "0.49916238", "0.49857712", "0.49818078", "0.49793446", "0.49768922", "0.4973069", "0.4967054", "0.49637303", "0.49632832", "0.49631613", "0.496266", "0.49577263", "0.4956912", "0.49560392", "0.49537683" ]
0.72635645
0
Initiate a generic request to load it with an ad
private static AdRequest getAdRequest() { AdRequest request = new AdRequest(); // add test devices request.addTestDevice(AdRequest.TEST_EMULATOR); request.addTestDevice("CF95DC53F383F9A836FD749F3EF439CD"); Log.d(AbstractSmsActivity.OLD_SCHOOL_SMS, "New AdRequest: Location=[" + request.getLocation() + "] Gender=[" + request.getGender() + "] Birthday=[" + request.getBirthday() + "] Keywords=[" + request.getKeywords() + "]"); return request; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void load(Request req);", "private void loadInterstitial(AdRequest adRequest) {\n mInterstitialAd.loadAd(adRequest);\n }", "private void requestNewBanner(){\n AdView mAdView = (AdView) findViewById(R.id.adView);\n AdRequest adRequest = new AdRequest.Builder().build();\n mAdView.loadAd(adRequest);\n }", "private void loadInterstitial() {\n AdRequest adRequest = new AdRequest.Builder()\n .setRequestAgent(\"android_studio:ad_template\").build();\n mInterstitialAd.loadAd(adRequest);\n }", "public void requestNewInterstitial() {\n AdRequest adRequest = new AdRequest.Builder().build();\n\n mInterstitialAd.loadAd(adRequest);\n }", "private void LoadAdd() {\n\t\tAdRequest adRequest = new AdRequest.Builder().build();\n\t\tmInterstitialAd.loadAd(adRequest);\n\t\t// Toast.makeText(MainActivity.this, \"loading\",\n\t\t// Toast.LENGTH_SHORT).show();\n\t}", "public void loadAds(){\n\t\tAdRequest adRequest = new AdRequest.Builder()\n\t .build();\n\t\t\n\t adView.loadAd(adRequest);\n\t}", "private void loadInterstitial() {\n AdRequest adRequest = new AdRequest.Builder()\n .setRequestAgent(\"android_studio:ad_template\").build();\n mInterstitialAd.loadAd(adRequest);\n }", "public void load() {\n a.G().a(this.context, this, getPlacementID(), new d.a() {\n public final <T> void a(T t) {\n AppnextAd appnextAd;\n try {\n appnextAd = a.G().a(Interstitial.this.context, (ArrayList<AppnextAd>) (ArrayList) t, Interstitial.this.getCreative(), (Ad) Interstitial.this);\n } catch (Throwable unused) {\n if (Interstitial.this.getOnAdErrorCallback() != null) {\n Interstitial.this.getOnAdErrorCallback().adError(AppnextError.NO_ADS);\n }\n appnextAd = null;\n }\n if (appnextAd != null) {\n if (Interstitial.this.getOnAdLoadedCallback() != null) {\n Interstitial.this.getOnAdLoadedCallback().adLoaded(appnextAd.getBannerID(), appnextAd.getCreativeType());\n }\n } else if (Interstitial.this.getOnAdErrorCallback() != null) {\n Interstitial.this.getOnAdErrorCallback().adError(AppnextError.NO_ADS);\n }\n }\n\n public final void error(String str) {\n if (Interstitial.this.getOnAdErrorCallback() != null) {\n Interstitial.this.getOnAdErrorCallback().adError(str);\n }\n }\n }, getCreative());\n }", "private void requestNewInterstitial() {\n mInterstitialAd = new InterstitialAd(this);\n mInterstitialAd.setAdUnitId(getString(R.string.interstitial_ad_unit_id));\n mInterstitialAd.setAdListener(new AdListener() {\n @Override\n public void onAdClosed() {\n requestNewInterstitial();\n Toast.makeText(getApplicationContext(),\"Ad Closed\",Toast.LENGTH_LONG).show();\n goToNextActivity();\n }\n\n @Override\n public void onAdLoaded() {\n super.onAdLoaded();\n Toast.makeText(getApplicationContext(),\"Ad Loaded\",Toast.LENGTH_LONG).show();\n }\n });\n AdRequest adRequest = new AdRequest.Builder().build();\n mInterstitialAd.loadAd(adRequest);\n }", "private void initAd() {\n\t\tmInterstitialAd = new InterstitialAd(mcq.this);\n\t\t// Defined in values/strings.xml\n\t\tmInterstitialAd.setAdUnitId(\"ca-app-pub-9971154848057782/1986029758\");\n\t}", "private AdRequest getAdRequest()\n\t{\n\t\tAdRequest.Builder adBuilder = new AdRequest.Builder();\n\t\tAdRequest adRequest;\n\t\tif (!this.isForChildDirectedTreatment && extras != null)\n\t\t{\n\t\t\tadBuilder.addNetworkExtrasBundle(AdMobAdapter.class, extras);\n\t\t}\n\t\tif (this.isForChildDirectedTreatment)\n\t\t{\n\t\t\tadBuilder.tagForChildDirectedTreatment(true);\n\t\t}\n\t\tif (!isReal) {\n\t\t\tadBuilder.addTestDevice(AdRequest.DEVICE_ID_EMULATOR);\n\t\t\tadBuilder.addTestDevice(getAdmobDeviceId());\n\t\t}\n\t\tadRequest = adBuilder.build();\n\t\treturn adRequest;\n\t}", "@Override\n public void run() {\n interstitial.setAdUnitId(AdmodData.Admod.interstial_ap_id);\n // Request for Ads\n AdRequest adRequest = new AdRequest.Builder().addTestDevice(\"E4195931F1BE473915004D979ED94A8E\").build();\n //AdRequest adRequest = new AdRequest.Builder().build();\n interstitial.loadAd(adRequest);\n\n\n // Prepare an Interstitial Ad Listener\n\n interstitial.setAdListener(new AdListener() {\n public void onAdLoaded() {\n\n displayInterstitial();\n }\n\n @Override\n public void onAdFailedToLoad(int errorCode) {\n Log.e(\"Full\", \"Full ADS Error\" + errorCode);\n super.onAdFailedToLoad(errorCode);\n\n }\n\n });\n\n\n }", "@Override\n\tpublic void initRequest() {\n\n\t}", "protected PublisherAdRequest appAdRequest() {\n if(nonPersonalizedAdsReqBundle == null) {\n nonPersonalizedAdsReqBundle = DFPConsent.GDPRStatusBundle(SuperApp.getAppContext());\n }\n\n String THE_HINDU_URL = \"http://www.thehindu.com\";\n\n PublisherAdRequest request;\n if(nonPersonalizedAdsReqBundle != null) {\n Bundle extras = new FacebookAdapter.FacebookExtrasBundleBuilder()\n .setNativeAdChoicesIconExpandable(false)\n .build();\n return new PublisherAdRequest.Builder()\n .addNetworkExtrasBundle(AdMobAdapter.class, nonPersonalizedAdsReqBundle)\n .addNetworkExtrasBundle(FacebookAdapter.class, extras)\n .setContentUrl(THE_HINDU_URL).build();\n\n }\n else {\n return new PublisherAdRequest.Builder().setContentUrl(THE_HINDU_URL).build();\n\n }\n }", "private void initAdView() {\n MobileAds.initialize(this, mContext.getString(R.string.banner_ad_unit_id));\n\n // Create an ad request. Check logcat output for the hashed device ID to\n // get test ads on a physical device. e.g.\n // \"Use AdRequest.Builder.addTestDevice(\"ABCDEF012345\") to get test ads on this device.\"\n AdRequest adRequest = new AdRequest.Builder()\n .addTestDevice(AdRequest.DEVICE_ID_EMULATOR)\n .build();\n mAdView.loadAd(adRequest);\n }", "private void initialize(){\n if(uri != null)\n httpUriRequest = getHttpGet(uri);\n httpClient = HttpClients.createDefault();\n }", "void requestBannerAd(@NonNull Context context, @NonNull String appId, @NonNull AdSize adSize) {\n adLayout =\n new RelativeLayout(context) {\n @Override\n protected void onAttachedToWindow() {\n super.onAttachedToWindow();\n attach();\n }\n\n @Override\n protected void onDetachedFromWindow() {\n super.onDetachedFromWindow();\n detach();\n }\n };\n int adLayoutHeight = adSize.getHeightInPixels(context);\n // If the height is 0 (e.g. for inline adaptive banner requests), use the closest supported size\n // as the height of the adLayout wrapper.\n if (adLayoutHeight <= 0) {\n float density = context.getResources().getDisplayMetrics().density;\n adLayoutHeight = Math.round(mAdConfig.getAdSize().getHeight() * density);\n }\n RelativeLayout.LayoutParams adViewLayoutParams =\n new RelativeLayout.LayoutParams(adSize.getWidthInPixels(context), adLayoutHeight);\n adLayout.setLayoutParams(adViewLayoutParams);\n\n Log.d(TAG, \"requestBannerAd: \" + this);\n mPendingRequestBanner = true;\n VungleInitializer.getInstance()\n .initialize(\n appId,\n context.getApplicationContext(),\n new VungleInitializer.VungleInitializationListener() {\n @Override\n public void onInitializeSuccess() {\n loadBanner();\n }\n\n @Override\n public void onInitializeError(String errorMessage) {\n Log.d(TAG, \"SDK init failed: \" + VungleBannerAdapter.this);\n VungleListener listener = getVungleListener();\n mVungleManager.removeActiveBannerAd(placementId, vungleBannerAd);\n if (mPendingRequestBanner && listener != null) {\n listener.onAdFailedToLoad(AdRequest.ERROR_CODE_INTERNAL_ERROR);\n }\n }\n });\n }", "public void beginExecute(WebRequest request) throws Exception {\r\n request.addParameter(\"aid\", \"123\");\r\n }", "private Request() {\n initFields();\n }", "private void startAdvertising() {\n client.startAdvertising(codeName,getResources().getString(R.string.service_id), connectionLifecycleCallback, new AdvertisingOptions(STRATEGY));\n }", "@Override\n public void onRequestFilled(AdColonyInterstitial ad) {\n mAd = ad;\n notifyLoaded();\n }", "private void initBannerAdmob() {\n }", "public static Ad requestAd( Context context, String keywords, String searchQuery )\n\t{\n\t\t// Verify Internet permission is available. Otherwise our HTTP request will fail with\n\t\t// an unhelpful NPE when writing out to the server.\n\t\tif ( context.checkCallingOrSelfPermission( android.Manifest.permission.INTERNET ) == PackageManager.PERMISSION_DENIED )\n\t\t{\n\t\t\tAdManager.clientError( \"Cannot request an ad without Internet permissions! \" +\n\t\t\t\t\t\"Open manifest.xml and just before the final </manifest> tag add: <uses-permission android:name=\\\"android.permission.INTERNET\\\" />\" );\n\t\t}\n\t\n\t\t// start off the thread to internationalize.\n\t\tAdMobLocalizer.init(context);\n\t\t\n\t\t// Call AdMob to get an ad.\n\t\tAd ad = null;\n\t\tlong start = System.currentTimeMillis();\n\t\t\n\t\tStringBuilder contents = new StringBuilder();\n\t\tString iconURL = null;\n\t\t\n\t\ttry\n\t\t{\n\t\t String postString = AdRequester.buildParamString(context, keywords, searchQuery);\n\n\t\t\t// Make the HTTP request for the ad.\n\t\t\tBufferedWriter writer = null;\n\t\t\tBufferedReader reader = null;\n\t\t\t\n\t\t\ttry\n\t\t\t{\n\t\t\t\tURL admob_url = new URL( ADMOB_ENDPOINT );\n\t\t\t\tHttpURLConnection connection = (HttpURLConnection) admob_url.openConnection();\n\t\t\t\tconnection.setRequestMethod( \"POST\" );\n\t\t\t\tconnection.setDoOutput( true );\n\t\t\t\tconnection.setRequestProperty( \"User-Agent\", AdManager.getUserAgent() ); // Android makes this \"Java0\" by default\n\t\t\t\tconnection.setRequestProperty( \"Content-Type\", \"application/x-www-form-urlencoded\" );\n\t\t\t\tconnection.setRequestProperty( \"Content-Length\", Integer.toString( postString.length() ) );\n\t\t\t\tconnection.setConnectTimeout( REQUEST_TIMEOUT );\n\t\t\t\tconnection.setReadTimeout( REQUEST_TIMEOUT );\n\t\t\t\tString body = postString;\n\n\t\t\t\tif ( Log.isLoggable( AdManager.LOG, Log.DEBUG ) )\n\t\t\t\t{\n\t\t\t\t\tLog.d( AdManager.LOG, \"Requesting an ad with POST parmams: \" + body );\n\t\t\t\t}\n\t\t\t\t\n\t\t\t\tOutputStream out = connection.getOutputStream();\n\t\t\t\twriter = new BufferedWriter( new OutputStreamWriter( out ) );\n\t\t\t\twriter.write( body );\n\t\t\t\twriter.close();\n\t\t\t\t\n\t\t\t\treader = new BufferedReader( new InputStreamReader( connection.getInputStream() ) );\n\t\t\t\tfor ( String line; (line = reader.readLine()) != null; )\n\t\t\t\t{\n\t\t\t\t\tcontents.append( line );\n\t\t\t\t}\n\t\t\t\n\t\t\t\t// Get the URL of the icon image to display with the ad text.\n\t\t\t\ticonURL = connection.getHeaderField( \"X-AdMob-Android-Category-Icon\" );\n\t\t\t\t\n\t\t\t\tif ( iconURL == null )\n\t\t\t\t{\n\t\t\t\t\t// Use the default icon if there was some problem.\n\t\t\t\t\ticonURL = \"http://mm.admob.com/static/android/tiles/default.png\";\n\t\t\t\t}\n\t\t\t}\n\t\t\tfinally\n\t\t\t{\n\t\t\t\t// Clean up.\n\t\t\t\ttry\n\t\t\t\t{\n\t\t\t\t\tif ( writer != null )\n\t\t\t\t\t{\n\t\t\t\t\t\twriter.close();\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t\tif ( reader != null )\n\t\t\t\t\t{\n\t\t\t\t\t\treader.close();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tcatch (Exception e)\n\t\t\t\t{\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\tcatch (Exception ex)\n\t\t{\n\t\t\tLog.w( AdManager.LOG, \"Could not get ad from AdMob servers.\", ex );\n\t\t}\n\n\t\t// Turn the response into an Ad object and return it.\n\t\tString html = contents.toString();\n\t\t\n\t\tif ( html != null )\n\t\t{\n\t\t\tad = Ad.createAd( context, html, iconURL );\n\t\t}\n\n\t\tif ( Log.isLoggable( AdManager.LOG, Log.INFO ) )\n\t\t{\n\t\t\tlong time = System.currentTimeMillis() - start;\n\t\t\t\n\t\t\tif ( ad == null )\n\t\t\t{\n\t\t\t\tLog.i( AdManager.LOG, \"Server replied that no ads are available (\" + time + \"ms)\" );\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tLog.i( AdManager.LOG, \"Ad returned in \" + time + \"ms: \" + ad );\n\t\t\t}\n\t\t}\n\t\t\n\t\treturn ad;\n\t}", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded() {\n }", "public static void LoadIntertitialAdmob(Activity activity, String selectAdsBackup, String idIntertitial, String idIntertitialBackup, String Hpk1,\n String Hpk2, String Hpk3, String Hpk4, String Hpk5 ) {\n Bundle extras = new AppLovinExtras.Builder()\n .setMuteAudio(true)\n .build();\n AdRequest request = new AdRequest.Builder().addKeyword(Hpk1).addKeyword(Hpk2)\n .addKeyword(Hpk3).addKeyword(Hpk4).addKeyword(Hpk5)\n .addNetworkExtrasBundle(ApplovinAdapter.class, extras)\n .build();\n InterstitialAd.load(activity, idIntertitial, request,\n new InterstitialAdLoadCallback() {\n @Override\n public void onAdLoaded(@NonNull InterstitialAd interstitialAd) {\n // The mInterstitialAd reference will be null until\n // an ad is loaded.\n mInterstitialAd = interstitialAd;\n Log.i(TAG, \"onAdLoaded\");\n }\n\n @Override\n public void onAdFailedToLoad(@NonNull LoadAdError loadAdError) {\n // Handle the error\n Log.i(TAG, loadAdError.getMessage());\n mInterstitialAd = null;\n }\n });\n\n switch (selectAdsBackup) {\n case \"APPLOVIN-M\":\n if (idIntertitialBackup.equals(\"\")){\n interstitialAd = new MaxInterstitialAd(\"qwerty12345\", activity);\n interstitialAd.loadAd();\n } else {\n interstitialAd = new MaxInterstitialAd(idIntertitialBackup, activity);\n interstitialAd.loadAd();\n }\n\n break;\n case \"MOPUB\":\n mInterstitial = new MoPubInterstitial(activity, idIntertitialBackup);\n mInterstitial.load();\n break;\n case \"APPLOVIN-D\":\n AdRequest.Builder builder = new AdRequest.Builder().addKeyword(Hpk1).addKeyword(Hpk2)\n .addKeyword(Hpk3).addKeyword(Hpk4).addKeyword(Hpk5);\n Bundle interstitialExtras = new Bundle();\n interstitialExtras.putString( \"zone_id\", idIntertitialBackup );\n builder.addCustomEventExtrasBundle( AppLovinCustomEventInterstitial.class, interstitialExtras );\n\n AppLovinSdk.getInstance(activity).getAdService().loadNextAd(AppLovinAdSize.INTERSTITIAL, new AppLovinAdLoadListener() {\n @Override\n public void adReceived(AppLovinAd ad) {\n loadedAd = ad;\n }\n\n @Override\n public void failedToReceiveAd(int errorCode) {\n // Look at AppLovinErrorCodes.java for list of error codes.\n }\n });\n interstitialAdlovin = AppLovinInterstitialAd.create(AppLovinSdk.getInstance(activity), activity);\n break;\n\n }\n }", "private void interstitialAds() {\n Log.d(TAG, \"interstitialAds invoked\");\n final RequestCallback requestCallback = new RequestCallback() {\n @Override\n public void onAdAvailable(Intent intent) {\n // Store the intent that will be used later to show the interstitial\n interstitialIntent = intent;\n Log.d(TAG, \"IS: Offers are available\");\n Toast.makeText(MainActivity.this, \"IS: Offers are available\", Toast.LENGTH_SHORT).show();\n showOW.setEnabled(false);\n }\n\n @Override\n public void onAdNotAvailable(AdFormat adFormat) {\n // Since we don't have an ad, it's best to reset the interstitial intent\n interstitialIntent = null;\n Log.d(TAG, \"IS: No ad available\");\n Toast.makeText(MainActivity.this, \"IS: No ad available\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onRequestError(RequestError requestError) {\n // Since we don't have an ad, it's best to reset the interstitial intent\n interstitialIntent = null;\n Log.d(TAG, \"IS: Something went wrong with the request: \" + requestError.getDescription());\n Toast.makeText(MainActivity.this, \"IS: Something went wrong with the request: \", Toast.LENGTH_SHORT).show();\n }\n };\n\n final Handler handler = new Handler();\n handler.postDelayed(new Runnable() {\n @Override\n public void run() {\n InterstitialRequester.create(requestCallback)\n .request(MainActivity.this);\n Log.d(TAG, \"Interst Request: added delay of 5 secs\");\n }\n }, 5000);\n }", "public static void initAd(Context context) {\n mInterstitialAd = new InterstitialAd(context,\"488896505197015_488906218529377\");\n requestNewInterstitial();\n loadNativeAd(context);\n }", "private void init() {\n AdvertisingRequest();// 广告列表请求线程\n setapiNoticeControllerList();\n }", "@Override\r\n public void onAdLoaded() {\n }", "@Override\n public void onAdLoaded(Ad ad) {\n }", "private void initRequest()\n\t{\n\t\tthis.request = new RestClientReportRequest();\n\t\tRequestHelper.copyConfigsToRequest(this.getConfigs(), this.request);\n\t\tRequestHelper.copyParamsToRequest(this.getParams(), this.request);\n\t\t\n\t\tthis.performQuery();\n\t}", "private void ads(View view){\n String ID = \"95b9dd1c47e6407db176bc2398bda2c8323030f814183567\" ;\n\n Appodeal.initialize((Activity)view.getContext(),ID,Appodeal.INTERSTITIAL);\n Appodeal.show((Activity)view.getContext(), Appodeal.INTERSTITIAL);\n Appodeal.isLoaded(Appodeal.INTERSTITIAL);\n\n }", "private Request() {}", "private Request() {}", "@Override\n public void onAdLoaded(Ad ad) {\n Log.d(TAG, \"Interstitial ad is loaded and ready to be displayed!\");\n // Show the ad\n\n }", "@Override\n public void onAdLoaded(Ad ad) {\n }", "private void initiateLoader() {\n ConnectivityManager connMgr = (ConnectivityManager)\n getSystemService(Context.CONNECTIVITY_SERVICE);\n\n // Get details on the currently active default data network\n NetworkInfo networkInfo = null;\n if (connMgr != null) {\n networkInfo = connMgr.getActiveNetworkInfo();\n }\n\n // If there is a network connection, fetch data\n if (networkInfo != null && networkInfo.isConnected()) {\n // Get a reference to the LoaderManager, in order to interact with loaders.\n avi.show();\n loadingIndicator.setVisibility(View.VISIBLE);\n errorContainer.setVisibility(View.GONE);\n LoaderManager loaderManager = getSupportLoaderManager();\n String url = BASE_URL + \"&from=\" + fromDate;\n url += \"&to=\" + toDate;\n url += \"&page=\" + currentPageNo;\n url += \"&sortBy=\" + sortPreference;\n if (queryText != null) {\n url += \"&q=\" + queryText;\n }\n\n Bundle args = new Bundle();\n args.putString(URL_KEY, url);\n if (forceLoad) {\n loaderManager.restartLoader(LAST_LOADER_ID, args, this);\n forceLoad = false;\n } else {\n LAST_LOADER_ID = NEWS_LOADER_ID;\n }\n if (!loaderInitiated) {\n loaderManager.initLoader(NEWS_LOADER_ID, args, this);\n loaderInitiated = true;\n } else {\n loaderManager.restartLoader(NEWS_LOADER_ID, args, this);\n }\n } else {\n avi.hide();\n loadingIndicator.setVisibility(View.GONE);\n ((TextView) errorContainer.findViewById(R.id.tvErrorDesc)).setText(R.string.no_conn_error_message);\n errorContainer.setVisibility(View.VISIBLE);\n }\n }", "private WebRequest() {\n initFields();\n }", "public static void adRequest(Activity activity, int layoutId)\n {\n }", "public interface InterstitialAdsRequester {\n \n /**\n * Registers interstitial ads display in the activity that requires this.\n * @param display \n */\n void registerInterstitialAdDisplay (InterstitialAdDisplay display);\n \n /**\n * This called when interstitial ad closed by the user or failed to open.\n * This allows activity to proceed what it planned to do after ad displayed.\n */\n void onInterstitialAdFinished();\n}", "Call mo35727a(Request request);", "@Override\r\n public void onAdLoaded()//When interstitial is ready to be shoved\r\n {\r\n mInterstitial.showAd();\r\n }", "@Override\n\tpublic View onCreateView(LayoutInflater inflater, ViewGroup container,\n\t\t\tBundle savedInstanceState) {\n\t\tView rootView = inflater.inflate(R.layout.targeting, container, false);\n\t\tViewGroup main = (ViewGroup) rootView.findViewById(R.id.main);\n\n\t\t// Adding custom parameters to the request\n\t\tMap<String, Object> customParams = new HashMap<String, Object>();\n\t\t// customParams.put(\"tm\", Integer.valueOf(-11));\n\n\t\t// create one adview with deferred loading\n\t\tString[] matchingKeywords = { \"ems\" };\n\t\tadView = new GuJEMSAdView(getActivity(), customParams,\n\t\t\t\tmatchingKeywords, null, R.layout.targeting_adview_top, false);\n\n\t\t// Programmatically add listeners\n\t\tadView.setOnAdSuccessListener(new IOnAdSuccessListener() {\n\n\t\t\tprivate static final long serialVersionUID = -9160587495885653766L;\n\n\t\t\t@Override\n\t\t\tpublic void onAdSuccess() {\n\n\t\t\t\tSystem.out.println(\"I received an ad. [Targeting-Top]\");\n\t\t\t}\n\t\t});\n\t\tadView.setOnAdEmptyListener(new IOnAdEmptyListener() {\n\n\t\t\tprivate static final long serialVersionUID = -3891758300923903713L;\n\n\t\t\t@Override\n\t\t\tpublic void onAdEmpty() {\n\n\t\t\t\tSystem.out.println(\"I received no ad! [Targeting-Top]\");\n\t\t\t}\n\t\t});\n\n\t\t// Programmatically add adview\n\t\tmain.addView(adView,\n\t\t\t\tmain.indexOfChild(rootView.findViewById(R.id.imageView1)));\n\n\t\t// Adding a keyword to the request\n\t\tMap<String, Object> customParams2 = new HashMap<String, Object>();\n\t\tcustomParams2.put(\"as\", 16542);\n\t\t// Create second adview with deferred loading\n\t\tadView2 = new GuJEMSAdView(getActivity(), customParams2, // customParams2,\n\t\t\t\tnull, // kws2,\n\t\t\t\tnull, R.layout.targeting_adview_bottom, false);\n\n\t\t// Programmatically add listeners\n\t\tadView2.setOnAdSuccessListener(new IOnAdSuccessListener() {\n\n\t\t\tprivate static final long serialVersionUID = -9160587495885653766L;\n\n\t\t\t@Override\n\t\t\tpublic void onAdSuccess() {\n\n\t\t\t\tSystem.out.println(\"I received an ad. [Targeting-Bottom]\");\n\t\t\t}\n\t\t});\n\t\tadView2.setOnAdEmptyListener(new IOnAdEmptyListener() {\n\n\t\t\tprivate static final long serialVersionUID = -3891758300923903713L;\n\n\t\t\t@Override\n\t\t\tpublic void onAdEmpty() {\n\n\t\t\t\tSystem.out.println(\"I received no ad! [Targeting-Bottom]\");\n\t\t\t}\n\t\t});\n\n\t\t// Programmatically add adview\n\n\t\tmain.addView(adView2,\n\t\t\t\tmain.indexOfChild(rootView.findViewById(R.id.sampleText)) + 1);\n\n\t\t// perform the actual ad request\n\t\tadView.load();\n\t\tadView2.load();\n\t\tgetActivity().setTitle(\"Targeting\");\n\t\treturn rootView;\n\t}", "public void loadData(){\n JsonArrayRequest request = new JsonArrayRequest(\"http://www.efstratiou.info/projects/newsfeed/getList.php\", netListener, errorListener);\n\n //submit request\n ArticlesApp.getInstance().getRequestQueue().add(request);\n\n }", "void getAdvert(String aid, final AdvertResult result);", "public void initIstance(HttpServletRequest request) {\n \tname = request.getParameter(\"name\");\n priceMin = request.getParameter(\"priceMin\");\n priceMax = request.getParameter(\"priceMax\");\n code = request.getParameter(\"code\");\n description = request.getParameter(\"description\");\n String hiddenStr = request.getParameter(\"hidden\");\n hidden = hiddenStr != null;\n typeIdes = request.getParameterValues(\"type\");\n }", "void request(RequestParams params);", "@Override\n public void loadFromRequestAdditional(PortletRequest request) {\n // ProtectBlock extraLoadFromRequestAdditional\n // ProtectBlock End\n }", "@Override\n public void onAdLoaded(Ad ad) {\n interstitialAd.show();\n enableButton();\n }", "public void startVolleyRequest(String tag,\n String accessToken) {\n String tag_json_obj = \"json_obj_req\";\n String url = createInstagramUrl(tag, accessToken);\n createJsonObjectRequest(url);\n }", "ThingsResponse loadThingsDetails(ThingsRequest request);", "com.google.openrtb.OpenRtb.BidRequest getRequest();", "@Override\n public void onAdLoaded(Ad ad) {\n Log.d(TAG, \"Interstitial ad is loaded and ready to be displayed!\");\n // Show the ad\n// interstitialAd.show();\n }", "@Override\n public void onAdFailedToLoad(int errorCode) {\n }", "@MainThread\n @Override\n protected void onForceLoad() {\n super.onForceLoad();\n cancelLoadHelper();\n\n makeRequest();\n }", "private void loadContent()\n {\n // locking the function to prevent the adapter\n // from calling multiples async requests with\n // the same definitions which produces duplicate\n // data.\n locker.lock();\n\n // this function contruct a GraphRequest to the next paging-cursor from previous GraphResponse.\n GraphRequest nextGraphRequest = lastGraphResponse.getRequestForPagedResults(GraphResponse.PagingDirection.NEXT);\n\n // if we reached the end of our pages, the above method 'getRequestForPagedResults'\n // return 'null' object\n if(nextGraphRequest != null)\n {\n // for clarificating and formatting purposes\n // I declared the callback besides the members\n // variables.\n nextGraphRequest.setCallback(callback);\n nextGraphRequest.executeAsync();\n }\n }", "private void addRequest(InstanceRequest request) {\r\n\t\t\r\n\t}", "public void build() {\n\t\t\tRequest request = new Request();\n request.context = context;\n\t\t\trequest.requestType = requestType;\n\t\t\trequest.url = url;\n\t\t\trequest.envelope = envelope;\n\t\t\trequest.headers = headers;\n\n\t\t\trequest.responseListener = responseListener;\n\t\t\trequest.onValidateResponseListener = validateResponseListener;\n\n\t\t\trequest.isDebug = isDebug;\n\n\t\t\trequest.start();\n\t\t}", "TransferInitiateResponse initiateProviderRequest(DataRequest dataRequest);", "protected void handleRequest(dk.i1.diameter.Message request, ConnectionKey connkey, Peer peer) {\n\n String log = \"\";\n Message answer = new Message();\n answer.prepareResponse(request);\n AVP avp;\n avp = request.find(ProtocolConstants.DI_SESSION_ID);\n if (avp != null)\n answer.add(avp);\n node().addOurHostAndRealm(answer);\n //avp = request.find(ProtocolConstants.DI_CC_REQUEST_TYPE); DIAMETER_COMMAND_AA\n avp = request.find(ProtocolConstants.DI_AUTH_REQUEST_TYPE);\n if (avp == null) {\n answerError(answer, connkey, ProtocolConstants.DIAMETER_RESULT_MISSING_AVP,\n new AVP[]{new AVP_Grouped(ProtocolConstants.DI_FAILED_AVP, new AVP[]{new AVP(ProtocolConstants.DI_AUTH_REQUEST_TYPE, new byte[]{})})});\n return;\n }\n\n\n int aa_request_type = -1;\n try {\n aa_request_type = new AVP_Unsigned32(avp).queryValue();\n } catch (InvalidAVPLengthException ex) {\n }\n if (aa_request_type != ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHENTICATE &&\n aa_request_type != ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHENTICATE_ONLY &&\n aa_request_type != ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHORIZE_ONLY) {\n answerError(answer, connkey, ProtocolConstants.DIAMETER_RESULT_INVALID_AVP_VALUE,\n new AVP[]{new AVP_Grouped(ProtocolConstants.DI_FAILED_AVP, new AVP[]{avp})});\n return;\n }\n\n\n\n avp = request.find(ProtocolConstants.DI_AUTH_APPLICATION_ID);\n if (avp != null)\n answer.add(avp);\n avp = request.find(ProtocolConstants.DI_AUTH_REQUEST_TYPE);\n if (avp != null)\n answer.add(avp);\n\n\n switch (aa_request_type) {\n case ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHENTICATE_ONLY:\n case ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHENTICATE:\n //grant whatever is requested\n avp = request.find(ProtocolConstants.DI_USER_NAME);\n answer.add(avp);\n String userName = new AVP_UTF8String(avp).queryValue();\n avp = request.find(ProtocolConstants.DI_USER_PASSWORD);\n String userPassword = new AVP_UTF8String(avp).queryValue();\n\n\n synchronized (PrintedStrings.stringsToPrint) {\n System.out.println(log = \"UserName: \" + userName);\n PrintedStrings.stringsToPrint.add(log);\n System.out.println(log = \"password: \" + userPassword);\n PrintedStrings.stringsToPrint.add(log);\n\n //TODO Sprawdzic to jesli nie ma z w slowniku\n String pass = userToPasswordDict.get(userName);\n if (pass == null) {\n System.out.println(log=\"nie ma takiego uzytkownika\");\n\n PrintedStrings.stringsToPrint.add(log);\n }\n if (userPassword.equals(pass)) {\n\n avp = request.find(ProtocolConstants.DI_CHAP_AUTH);\n if (avp != null) {\n try {\n AVP_Grouped chapAuth = new AVP_Grouped(avp);\n AVP[] elements = chapAuth.queryAVPs();\n byte[] idBytes = new AVP_OctetString(elements[1]).queryValue();\n char id = (char) idBytes[0];\n System.out.println(log = \"id: \" + id);\n PrintedStrings.stringsToPrint.add(log);\n\n byte[] chapResponseBytes = new AVP_OctetString(elements[2]).queryValue();\n printBytesAsString(chapResponseBytes, \"odebrane rozwiazanie \");\n log = getBytesAsString(chapResponseBytes, \"odebrane rozwiazanie \");\n PrintedStrings.stringsToPrint.add(log);\n\n byte[] chapChallengeBytes = new AVP_OctetString(elements[3]).queryValue();\n printBytesAsString(chapChallengeBytes, \"odebrane zadanie \");\n log = getBytesAsString(chapResponseBytes, \"odebrane zadanie \");\n PrintedStrings.stringsToPrint.add(log);\n\n //sprawdzenie czy nie ma ataku przez odtwarzanie\n ServicingUserEntry sessionEntry = curentlyServicing.get(userName);\n if (sessionEntry == null) {\n System.out.println(log = \"Atak/ pakiet dotarl po upłynieciu czasu oczekiwania/ pakiet został powtórzony\");\n //w takiej sytuacji nie odpowiadamy wcale\n PrintedStrings.stringsToPrint.add(log);\n return;\n }\n Date now = new Date();\n if (id != sessionEntry.getId() ||\n !Arrays.equals(chapChallengeBytes, sessionEntry.getChallenge()) ||\n (now.getTime() - sessionEntry.getTime().getTime()) > 5000) {\n\n System.out.println(log = \"Atak/ pakiet dotarl po upłynieciu czasu oczekiwania/ przekłamanie pakietu\");\n //w takiej sytuacji nie odpowiadamy wcale\n PrintedStrings.stringsToPrint.add(log);\n return;\n }\n curentlyServicing.remove(userName);\n byte[] md5 = caluculateMD5(idBytes, userToSecretDict.get(userName).getBytes(\"ASCII\"), chapChallengeBytes);\n printBytesAsString(chapResponseBytes, \"obliczone rozwiazanie \");\n log = getBytesAsString(chapResponseBytes, \"obliczone rozwiazanie \");\n PrintedStrings.stringsToPrint.add(log);\n\n if (Arrays.equals(chapResponseBytes, md5)) {\n\n answer.add(new AVP_OctetString(ProtocolConstants.DI_FRAMED_IP_ADDRESS, clusterAddress.getBytes()));\n answer.add(new AVP_Unsigned32(ProtocolConstants.DI_RESULT_CODE, ProtocolConstants.DIAMETER_RESULT_SUCCESS));\n System.out.println(log = \"Uwierzytelnionio, pozwalam na dołaczenie do klastra\");\n PrintedStrings.stringsToPrint.add(log);\n } else {\n answer.add(new AVP_Unsigned32(ProtocolConstants.DI_RESULT_CODE, ProtocolConstants.DIAMETER_RESULT_AUTHENTICATION_REJECTED));\n System.out.println(log = \"Błędnie rozwiązane zadanie\");\n PrintedStrings.stringsToPrint.add(log);\n }\n } catch (InvalidAVPLengthException e) {\n e.printStackTrace();\n } catch (UnsupportedEncodingException e) {\n e.printStackTrace();\n }\n\n } else {\n answer.add(new AVP_Unsigned32(ProtocolConstants.DI_RESULT_CODE, ProtocolConstants.DIAMETER_RESULT_MULTI_ROUND_AUTH));\n //zwiekszamy ostatnio uzywany index o 1 i korzystamy z niego\n incrementIndex();\n byte[] ind = new byte[]{(byte) lastId};\n byte[] challenge = generateChallenge();\n printBytesAsString(challenge, \"wygenerowane zadanie \");\n log = getBytesAsString(challenge, \"wygenerowane zadanie \");\n PrintedStrings.stringsToPrint.add(log);\n\n\n curentlyServicing.put(userName, new ServicingUserEntry(userName, challenge, lastId));\n //System.out.println(\"generated chalenge : \" + challenge.toString());\n answer.add(new AVP_Grouped(ProtocolConstants.DI_CHAP_AUTH,\n new AVP_Integer32(ProtocolConstants.DI_CHAP_ALGORITHM, 5),\n new AVP_OctetString(ProtocolConstants.DI_CHAP_IDENT, ind),\n new AVP_OctetString(ProtocolConstants.DI_CHAP_CHALLENGE, challenge)));\n\n\n if(lastId==34)\n serverGUIController.firstInClaster = true; //TODO obsluz wszsytkich\n if(lastId==35)\n serverGUIController.secondInClaster = true;\n if(lastId==36)\n serverGUIController.thirdInClaster = true;\n if(lastId==37)\n serverGUIController.fourthInClaster = true;\n }\n } else {\n answer.add(new AVP_Unsigned32(ProtocolConstants.DI_RESULT_CODE, ProtocolConstants.DIAMETER_RESULT_AUTHENTICATION_REJECTED));\n log=\"podane hasło jest niepoprawne\";\n PrintedStrings.stringsToPrint.add(log);\n }\n }\n case ProtocolConstants.DI_AUTH_REQUEST_TYPE_AUTHORIZE_ONLY:\n break;\n }\n\n Utils.setMandatory_RFC3588(answer);\n\n try {\n answer(answer, connkey);\n } catch (dk.i1.diameter.node.NotAnAnswerException ex) {\n }\n\n switch (lastId) {\n case 34: {\n serverGUIController.firstConnected = true;\n serverGUIController.firstTextClear = true;\n break;\n }\n case 35:{\n serverGUIController.secondConnected = true;\n serverGUIController.secondTextClear = true;\n break;\n }\n case 36:{\n serverGUIController.thirdConnected = true;\n serverGUIController.thirdTextClear = true;\n break;\n }\n case 37:{\n serverGUIController.fourthCOnnected = true;\n serverGUIController.fourthTextClear = true;\n break;\n }\n\n }\n\n }", "private void loadURLRequest() {\n if (news.getUrl() != null) {\n Intent loadNews = new Intent(itemView.getContext(), WebViewActivity.class);\n loadNews.putExtra(\"URL\", news.getUrl());\n loadNews.addFlags(Intent.FLAG_ACTIVITY_NEW_TASK);\n itemView.getContext().startActivity(loadNews);\n }\n }", "@Override\n\tpublic void onRequestStart(String reqId) {\n\t\t\n\t}", "@Override\n public void onAdLoaded(Ad ad) {\n Log.d(TAG, \"Interstitial ad is loaded and ready to be displayed!\");\n // Show the ad\n //pd.cancel();\n interstitialAd.show();\n }", "@Override\n public void onAdLoaded() {\n Log.d(\"TAG\",\"Ad loaded\");\n }", "@Override\n public void onAdLoaded(Ad ad) {\n Log.d(TAG, \"Interstitial ad is loaded and ready to be displayed!\");\n\n }", "@Override\n\tpublic void start(AdsArgs... args) {\n\t\t\n\t}", "private void initChatbot(){\n final AIConfiguration config = new AIConfiguration(dialogFlowKey,\n AIConfiguration.SupportedLanguages.English,AIConfiguration.RecognitionEngine.System);\n aiDataService = new AIDataService(getActivity(),config);\n customAIServiceContext = AIServiceContextBuilder.buildFromSessionId(uuid);\n aiRequest = new AIRequest();\n\n }", "private void loadBannerAds() {\n // Load the first banner ad in the items list (subsequent ads will be loaded automatically\n // in sequence).\n loadBannerAd(0);\n }", "private static AdResponseParcel m5544a(Context context, C0552b bVar, AdRequestInfoParcel adRequestInfoParcel) {\n bqgg bqgg;\n boolean z;\n bqgg bqgg2;\n Bundle bundle;\n bqgg bqgg3;\n String str;\n C0386k kVar;\n String str2;\n C0384i iVar;\n C0563m mVar;\n AdResponseParcel adResponseParcel;\n char c;\n Context context2 = context;\n C0552b bVar2 = bVar;\n AdRequestInfoParcel adRequestInfoParcel2 = adRequestInfoParcel;\n C0633h.m5664a(\"Starting ad request from service using: google.afma.request.getAdDictionary\");\n C0386k kVar2 = new C0386k(((Boolean) C0395h.f8335b.mo6621a()).booleanValue(), \"load_ad\", adRequestInfoParcel2.f8611d.f8140a);\n if (adRequestInfoParcel2.f8601a > 10) {\n long j = adRequestInfoParcel2.f8575A;\n if (j != -1) {\n kVar2.mo6618a(kVar2.mo6617a(j), \"cts\");\n }\n }\n C0384i a = kVar2.mo6616a();\n bqgg a2 = bqga.m112773a(bVar2.f8722f.mo6707a(context2), ((Long) C0371o.f8227ae.mo6604a()).longValue(), TimeUnit.MILLISECONDS, C0645d.f8975c);\n bqgg a3 = bqga.m112775a((Object) null);\n if (((Boolean) C0371o.f8214aA.mo6604a()).booleanValue()) {\n bqgg = bVar2.f8719c.getDoritosCookieAsynchronously(adRequestInfoParcel2.f8614g.packageName);\n } else {\n bqgg = a3;\n }\n bqgg doritosCookiesAsynchronously = bVar2.f8719c.getDoritosCookiesAsynchronously(adRequestInfoParcel2.f8614g.packageName);\n bqgg a4 = bVar2.f8723g.mo6382a(adRequestInfoParcel2.f8615h, adRequestInfoParcel2.f8614g);\n Future a5 = C0387d.m5369g().mo6747a(context2);\n bqgg a6 = bqga.m112775a((Object) null);\n Bundle bundle2 = adRequestInfoParcel2.f8610c.f8120c;\n if (bundle2 == null || bundle2.getString(\"_ad\") == null) {\n z = false;\n } else {\n z = true;\n }\n if (adRequestInfoParcel2.f8581G && !z) {\n a6 = bVar2.f8721e.mo6698a(adRequestInfoParcel2.f8613f);\n }\n bqgg a7 = bqga.m112773a(a6, ((Long) C0371o.f8225ac.mo6604a()).longValue(), TimeUnit.MILLISECONDS, C0645d.f8975c);\n bqgg a8 = bqga.m112775a((Object) null);\n if (((Boolean) C0371o.f8192F.mo6604a()).booleanValue()) {\n bqgg2 = bqga.m112773a(bVar2.f8723g.mo6380a(context2), ((Long) C0371o.f8193G.mo6604a()).longValue(), TimeUnit.MILLISECONDS, C0645d.f8975c);\n } else {\n bqgg2 = a8;\n }\n if (adRequestInfoParcel2.f8601a < 4 || (bundle = adRequestInfoParcel2.f8622o) == null) {\n bundle = null;\n }\n if (bundle == null && ((Boolean) C0390c.f8324b.mo6621a()).booleanValue()) {\n bundle = new Bundle();\n }\n Bundle bundle3 = bundle;\n if (bundle3 != null) {\n bqgg3 = C0645d.f8973a.mo25819b(new C0554d(bVar2, context2, adRequestInfoParcel2, bundle3));\n } else {\n bqgg3 = null;\n }\n if (C0387d.m5363a().mo6856a(context2, \"android.permission.ACCESS_NETWORK_STATE\") && ((ConnectivityManager) context2.getSystemService(\"connectivity\")).getActiveNetworkInfo() == null) {\n C0633h.m5664a(\"Device is offline.\");\n }\n if (adRequestInfoParcel2.f8601a >= 7) {\n str = adRequestInfoParcel2.f8629v;\n } else {\n str = UUID.randomUUID().toString();\n }\n Bundle bundle4 = adRequestInfoParcel2.f8610c.f8120c;\n if (bundle4 != null) {\n kVar = kVar2;\n String string = bundle4.getString(\"_ad\");\n if (string != null) {\n return C0558h.m5554a(context2, adRequestInfoParcel2, string);\n }\n } else {\n kVar = kVar2;\n }\n List a9 = bVar2.f8725i.mo6443a(adRequestInfoParcel2.f8630w);\n if (bqgg3 != null) {\n try {\n iVar = a;\n str2 = str;\n try {\n bqgg3.get(((Long) C0390c.f8323a.mo6621a()).longValue(), TimeUnit.MILLISECONDS);\n } catch (InterruptedException | ExecutionException e) {\n e = e;\n } catch (TimeoutException e2) {\n C0633h.m5664a(\"Timed out waiting for app index fetching task\");\n Bundle bundle5 = (Bundle) C0647f.m5687a(a2, null, ((Long) C0371o.f8227ae.mo6604a()).longValue(), TimeUnit.MILLISECONDS);\n Location location = (Location) C0647f.m5686a(a7);\n C0271c cVar = (C0271c) C0647f.m5686a(bqgg2);\n String str3 = (String) C0647f.m5686a(a4);\n String str4 = (String) C0647f.m5686a(bqgg);\n String str5 = (String) C0647f.m5686a(doritosCookiesAsynchronously);\n mVar = (C0563m) C0647f.m5686a(a5);\n if (mVar != null) {\n }\n }\n } catch (InterruptedException | ExecutionException e3) {\n e = e3;\n iVar = a;\n str2 = str;\n C0633h.m5673d(\"Failed to fetch app index signal\", e);\n Bundle bundle52 = (Bundle) C0647f.m5687a(a2, null, ((Long) C0371o.f8227ae.mo6604a()).longValue(), TimeUnit.MILLISECONDS);\n Location location2 = (Location) C0647f.m5686a(a7);\n C0271c cVar2 = (C0271c) C0647f.m5686a(bqgg2);\n String str32 = (String) C0647f.m5686a(a4);\n String str42 = (String) C0647f.m5686a(bqgg);\n String str52 = (String) C0647f.m5686a(doritosCookiesAsynchronously);\n mVar = (C0563m) C0647f.m5686a(a5);\n if (mVar != null) {\n }\n } catch (TimeoutException e4) {\n iVar = a;\n str2 = str;\n C0633h.m5664a(\"Timed out waiting for app index fetching task\");\n Bundle bundle522 = (Bundle) C0647f.m5687a(a2, null, ((Long) C0371o.f8227ae.mo6604a()).longValue(), TimeUnit.MILLISECONDS);\n Location location22 = (Location) C0647f.m5686a(a7);\n C0271c cVar22 = (C0271c) C0647f.m5686a(bqgg2);\n String str322 = (String) C0647f.m5686a(a4);\n String str422 = (String) C0647f.m5686a(bqgg);\n String str522 = (String) C0647f.m5686a(doritosCookiesAsynchronously);\n mVar = (C0563m) C0647f.m5686a(a5);\n if (mVar != null) {\n }\n }\n } else {\n iVar = a;\n str2 = str;\n }\n Bundle bundle5222 = (Bundle) C0647f.m5687a(a2, null, ((Long) C0371o.f8227ae.mo6604a()).longValue(), TimeUnit.MILLISECONDS);\n Location location222 = (Location) C0647f.m5686a(a7);\n C0271c cVar222 = (C0271c) C0647f.m5686a(bqgg2);\n String str3222 = (String) C0647f.m5686a(a4);\n String str4222 = (String) C0647f.m5686a(bqgg);\n String str5222 = (String) C0647f.m5686a(doritosCookiesAsynchronously);\n mVar = (C0563m) C0647f.m5686a(a5);\n if (mVar != null) {\n C0633h.m5672d(\"Error fetching device info. This is not recoverable.\");\n return new AdResponseParcel(0);\n }\n C0551a aVar = new C0551a();\n aVar.f8714i = adRequestInfoParcel2;\n aVar.f8715j = mVar;\n aVar.f8709d = location222;\n aVar.f8707b = bundle5222;\n aVar.f8712g = str3222;\n aVar.f8713h = cVar222;\n if (a9 == null) {\n aVar.f8708c.clear();\n }\n aVar.f8708c = a9;\n aVar.f8706a = bundle3;\n aVar.f8710e = str4222;\n aVar.f8711f = str5222;\n aVar.f8716k = bVar2.f8718b.mo6419a(context2);\n boolean z2 = bVar2.f8724h;\n JSONObject a10 = C0558h.m5556a(context2, aVar);\n if (a10 == null) {\n return new AdResponseParcel(0);\n }\n if (adRequestInfoParcel2.f8601a < 7) {\n try {\n a10.put(\"request_id\", str2);\n } catch (JSONException e5) {\n }\n }\n C0386k kVar3 = kVar;\n C0384i iVar2 = iVar;\n kVar3.mo6618a(iVar2, \"arc\");\n bqgg a11 = bqga.m112773a(bqdx.m112674a(bVar2.f8726j.f8860a.mo6670b(a10), C0553c.f8727a, C0645d.f8973a), 10, TimeUnit.SECONDS, C0645d.f8975c);\n bqgg a12 = bVar2.f8720d.mo6748a();\n if (a12 != null) {\n C0647f.m5688a(a12, \"AdRequestServiceImpl.loadAd.flags\");\n }\n C0561k kVar4 = (C0561k) C0647f.m5686a(a11);\n if (kVar4 == null) {\n return new AdResponseParcel(0);\n }\n int i = kVar4.f8786g;\n if (i != -2) {\n return new AdResponseParcel(i);\n }\n synchronized (kVar3.f8298c) {\n }\n if (!TextUtils.isEmpty(kVar4.f8784e)) {\n adResponseParcel = C0558h.m5554a(context2, adRequestInfoParcel2, kVar4.f8784e);\n } else {\n adResponseParcel = null;\n }\n if (adResponseParcel == null && !TextUtils.isEmpty(kVar4.f8785f)) {\n adResponseParcel = m5545a(adRequestInfoParcel, context, adRequestInfoParcel2.f8618k.f8949a, kVar4.f8785f, str4222, str5222, kVar4, kVar3, bVar);\n }\n if (adResponseParcel != null) {\n c = 0;\n } else {\n c = 0;\n adResponseParcel = new AdResponseParcel(0);\n }\n String[] strArr = new String[1];\n strArr[c] = \"tts\";\n kVar3.mo6618a(iVar2, strArr);\n adResponseParcel.f8685y = kVar3.mo6619b();\n adResponseParcel.f8657X = kVar4.f8789j;\n return adResponseParcel;\n }", "void setRequest(Request req);", "private void populateInterfaceElements() {\n sponsoredAdTextView.setTypeface(Default.sourceSansProBold);\n adFailedTextView.setTypeface(Default.sourceSansProBold);\n\n adRequest = new AdRequest.Builder().build();\n adView.loadAd(adRequest);\n adView.setAdListener(new AdListener() {\n @Override\n public void onAdLoaded() {\n // Code to be executed when an ad finishes loading.\n sponsoredLinearLayout.setVisibility(View.VISIBLE);\n adView.setVisibility(View.VISIBLE);\n adProgressBar.setVisibility(View.GONE);\n adFailedLinearLayout.setVisibility(View.GONE);\n }\n\n @Override\n public void onAdFailedToLoad(int errorCode) {\n // Code to be executed when an ad request fails.\n sponsoredLinearLayout.setVisibility(View.GONE);\n adView.setVisibility(View.GONE);\n adProgressBar.setVisibility(View.GONE);\n adFailedLinearLayout.setVisibility(View.VISIBLE);\n }\n\n @Override\n public void onAdOpened() {\n // Code to be executed when an ad opens an overlay that\n // covers the screen.\n }\n\n @Override\n public void onAdLeftApplication() {\n // Code to be executed when the user has left the app.\n }\n\n @Override\n public void onAdClosed() {\n // Code to be executed when when the user is about to return\n // to the app after tapping on an ad.\n }\n });\n }", "public Request loadRequestDetail(long _requestId) throws RequestManagerException, PersistenceResourceAccessException;", "private RequestExecution() {}", "ContentLoader getContentLoader(ClientRequestContext context);", "public interface AdController {\n void setupAds();\n RelativeLayout setBannerOnView(View gameView);\n void showBannedAd();\n void hideBannerAd();\n boolean isWifiConnected();\n void showInterstellarAd(Runnable then);\n void showInterstellar();\n void setInterstitialCount(int countInterstitial);\n void hideInterstellarAd(Runnable then);\n InterstitialAd getInterstitialAd();\n}", "@Override\n protected void doInit() {\n super.doInit();\n this.startTime = (String) this.getRequest().getAttributes().get(\"startTime\");\n this.endTime = (String) this.getRequest().getAttributes().get(\"endTime\");\n this.interval = (String) this.getRequest().getAttributes().get(\"samplingInterval\");\n }", "private void loadBuyer() {\n swipeLayout.setRefreshing(true);\n JsonObjectRequest request = new JsonObjectRequest(Request.Method.GET, apiUrl, null, response -> {\n\n try {\n if(!response.getBoolean(\"status\")) {\n alert.setMessage(response.getJSONObject(\"data\").getString(\"message\"))\n .show();\n } else {\n JSONObject buyer = response.getJSONObject(\"data\");\n fieldName.setText(buyer.getString(\"name\"));\n fieldPhone.setText(buyer.getString(\"phone\"));\n fieldAddress.setText(buyer.getString(\"address\"));\n fieldVillage.setText(buyer.getString(\"village\"));\n fieldDistrict.setText(buyer.getString(\"district\"));\n fieldCity.setText(buyer.getString(\"city\"));\n fieldProvince.setText(buyer.getString(\"province\"));\n fieldPos.setText(buyer.getString(\"postal_code\"));\n }\n } catch (JSONException e) {\n e.printStackTrace();\n alert.setMessage(e.getMessage()).show();\n }\n\n swipeLayout.setRefreshing(false);\n\n }, error -> {\n swipeLayout.setRefreshing(false);\n }) {\n @Override\n public Map<String, String> getHeaders() throws AuthFailureError {\n return RequestGlobalHeaders.get(getApplicationContext());\n }\n };\n\n requestQueue.add(request);\n }", "public abstract void mo20127a(AdRsp adRsp);", "@Override\n\tprotected String route() {\n\t\treturn \"api/ad\";\n\t}", "private AutoCompleteGalRequest() {\n this((String) null);\n }", "@Override\n\tprotected void init() throws SiDCException, Exception {\n\t\tLogAction.getInstance().debug(\"Request:\" + entity);\n\t}", "@Override\n\tprotected void init() throws SiDCException, Exception {\n\t\tLogAction.getInstance().debug(\"Request:\" + entity);\n\t}", "public void adRequest(String vName, Integer length) {\n curState.adRequest(vName, length, this, result);\n }", "@Override\n\t\t\t\t\tpublic void onReqStart() {\n\t\t\t\t\t}", "@Override\n\tprotected void loadInterstitial(Context context, CustomEventInterstitialListener listener, Map<String, Object> localExtras, Map<String, String> serverExtras) {\n\n\t\tthis.listener = listener;\n\n\t\tMoPubExtension.log(\"Creating a SAS interstitial ...\");\n\t\tthis.interstitial = new SASInterstitialView(context);\n\n\t\tMoPubExtension.log(\"Getting interstitial parameters ...\");\n\t\tsiteId = SmartAdUtils.getSiteIdFromServerExtras(serverExtras);\n\t\tpageId = SmartAdUtils.getPageIdFromServerExtras(serverExtras);\n\t\tformatId = SmartAdUtils.getFormatIdFromServerExtras(serverExtras);\n\t\ttarget = SmartAdUtils.getTargetFromServerExtras(serverExtras);\n\t\tretryDelay = SmartAdUtils.getRetryDelayFromServerExtras(serverExtras);\n\n\t\tif(siteId == null || pageId == null || formatId == null || target == null || retryDelay == null) {\n\t\t\tMoPubExtension.logE(\"Invalid SmartAdServer parameters ! Configure network on MoPub to provide custom data : \"\n\t\t\t\t\t+ \"{\\\"siteId\\\":YOUR_SITE_ID, \\\"pageId\\\":YOUR_PAGE_ID, \\\"formatId\\\":YOUR_FORMAT_ID, \\\"target\\\":YOUR_TARGET, \\\"retryDelay\\\":DELAY_IN_SECONDS}\");\n\t\t\tlistener.onInterstitialFailed(MoPubErrorCode.ADAPTER_CONFIGURATION_ERROR);\n\t\t\treturn;\n\t\t}\n\t\t\n\t\tif(lastImpressionFailedAt > 0 && (new Date().getTime() - lastImpressionFailedAt) < (retryDelay * 1000)) {\n\t\t\tMoPubExtension.log(\"Last SAS attempt failed too soon ago. Telling MoPub the fetch failed.\");\n\t\t\tlistener.onInterstitialFailed(MoPubErrorCode.NETWORK_NO_FILL);\n\t\t}\n\t\telse {\n\t\t\tMoPubExtension.log(\"Faking fetch of an SAS interstitial ad with parameters : \"\n\t\t\t\t\t+ \"[siteId:\" + siteId + \", pageId:\" + pageId + \", formatId:\" + formatId + \", target:\" + target + \", retryDelay:\" + retryDelay + \"]\");\n\t\t\tlastImpressionFailedAt = 0;\n\t\t\tlistener.onInterstitialLoaded();\n\t\t}\n\t\t\n\t\tthis.interstitial.setLocation(LocationService.getLastKnownLocation(context, MoPub.getLocationPrecision(), MoPub.getLocationAwareness()));\n\t}", "public void loadInterstitial(final String id)\n\t{\n\t\tactivity.runOnUiThread(new Runnable()\n\t\t{\n\t\t\t@Override public void run()\n\t\t\t{\n\t\t\t\tinterstitial = new Interstitial(id, getAdRequest(), activity, instanceId);\n\t\t\t}\n\t\t});\n\t}", "@Override\n public void setData(final AdMob adMob){\n\n AdRequest adRequest = new AdRequest.Builder()\n .build();\n adMobView.loadAd(adRequest);\n }", "public Ads() {\n }", "public void requestFreshAd() {\n // Get a message from AdMob to the developer here. Only run once and only run on the emulator.\n Context context = getContext();\n if (AdManager.getUserId(context) == null && !checkedForMessages) // null means this is emulator.\n {\n // go get the developer messages.\n checkedForMessages = true;\n retrieveDeveloperMessage(context);\n }\n\n // Only get an ad when this view is visible and not already getting an ad.\n if (super.getVisibility() != View.VISIBLE) {\n // Getting an ad when the view is hidden means it might not be shown to the user.\n // This greatly impairs AdMob's ability to optimize ads.\n Log.w(AdManager.LOG, \"Cannot requestFreshAd() when the AdView is not visible. Call AdView.setVisibility(View.VISIBLE) first.\");\n } else if (requestingFreshAd) {\n if (Log.isLoggable(AdManager.LOG, Log.DEBUG)) {\n Log.d(AdManager.LOG, \"Ignoring requestFreshAd() because we are already getting a fresh ad.\");\n }\n } else {\n requestingFreshAd = true;\n\n // get a uithreadHandler for post callbacks.\n if (uiThreadHandler == null) {\n uiThreadHandler = new Handler();\n }\n\n // Get the new ad on a background thread so the UI thread isn't blocked.\n new Thread() {\n public void run() {\n try {\n // Get a new Ad from AdMob.\n Context context = getContext();\n Ad newAd = AdRequester.requestAd(context, keywords, searchQuery);\n\n if (newAd != null) // we got an ad back\n {\n synchronized (this) {\n // Did we get a different ad than we're already showing?\n // always rotate if in test mode.\n if ((ad != null) && newAd.equals(ad.getAd()) && !AdManager.isInTestMode()) {\n if (Log.isLoggable(AdManager.LOG, Log.DEBUG)) {\n Log.d(AdManager.LOG, \"Received the same ad we already had. Discarding it.\");\n }\n\n requestingFreshAd = false;\n } else // let's show our brand new ad!\n {\n // Create a view for the ad.\n final boolean firstAd = (ad == null);\n final int visibility = AdView.super.getVisibility();\n\n final AdContainer newAdContainer = new AdContainer(newAd, context);\n newAdContainer.setBackgroundColor(getBackgroundColor());\n newAdContainer.setTextColor(getTextColor());\n newAdContainer.setVisibility(visibility);\n LayoutParams params = new LayoutParams(LayoutParams.FILL_PARENT, HEIGHT);\n newAdContainer.setLayoutParams(params);\n\n // Notify the client event listener.\n if (listener != null) {\n try {\n listener.onNewAd();\n listener.onReceiveAd(AdView.this);\n } catch (Exception e) {\n Log.w(AdManager.LOG, \"Unhandled exception raised in your AdListener.onReceiveAd.\", e);\n }\n }\n\n // Force this view to show the newAdContainer view.\n uiThreadHandler.post(new Runnable() {\n public void run() {\n try {\n // Place the ad container into this view group.\n addView(newAdContainer);\n\n // Perform an animation to swap the new ad for the old.\n if (visibility == View.VISIBLE) {\n if (firstAd) {\n applyFadeIn(newAdContainer);\n } else {\n applyRotation(newAdContainer);\n }\n } else {\n // Just record the new ad for when this becomes visible.\n ad = newAdContainer;\n }\n } catch (Exception e) {\n Log.e(AdManager.LOG, \"Unhandled exception placing AdContainer into AdView.\", e);\n } finally {\n // Done requesting a new ad.\n requestingFreshAd = false;\n }\n }\n });\n }\n }\n } else // Did not get an ad back\n {\n // Notify the client event listener.\n if (listener != null) {\n try {\n listener.onFailedToReceiveAd(AdView.this);\n } catch (Exception e) {\n Log.w(AdManager.LOG, \"Unhandled exception raised in your AdListener.onFailedToReceiveAd.\", e);\n }\n }\n\n requestingFreshAd = false;\n }\n } catch (Exception e) {\n Log.e(AdManager.LOG, \"Unhandled exception requesting a fresh ad.\", e);\n requestingFreshAd = false;\n }\n }\n }.start();\n }\n }", "private void startGame() {\n if (!interstitialAd.isLoading() && !interstitialAd.isLoaded()) {\n AdRequest adRequest = new AdRequest.Builder().build();\n interstitialAd.loadAd(adRequest);\n }\n\n // retryButton.setVisibility(View.INVISIBLE);\n\n }", "@Override\n\tprotected void initData() {\n\t\tisSearch = (boolean) getIntent().getExtras().getBoolean(Constant.IntentKey.isSearch,false);\n\t\t\n\t\tif (isSearch) {//非来自直播列表\n\t\t\tarticleID = getIntent().getExtras().getLong(Constant.IntentKey.articleID);\n//\t\t\tprogressActivity.showLoading();\n\t\t\t\n\t\t\t// 查询发现详情\n\t\t\tobtainDetailRequest();\n\t\t} else {\n\t\t\tsquareLiveModel = (SquareLiveModel) getIntent().getExtras().getSerializable(Constant.IntentKey.squareLiveModel);\n\t\t\t\n\t\t\tinitLoadView();\n\t\t}\n\t\t\n\t\t//启动定时器\n//\t\tinitTimerTask();\n\t}" ]
[ "0.6661345", "0.6363776", "0.6234573", "0.6139343", "0.6061303", "0.60573554", "0.59844697", "0.59257483", "0.59040254", "0.57429403", "0.57202435", "0.5581557", "0.5555274", "0.55363405", "0.5481522", "0.54217976", "0.53774524", "0.53597283", "0.53577816", "0.53555787", "0.53491235", "0.53388834", "0.53204817", "0.5313824", "0.5301196", "0.5301196", "0.5301196", "0.5301196", "0.5301196", "0.5301196", "0.5301196", "0.5301196", "0.5297325", "0.5269939", "0.52687824", "0.52351785", "0.52310646", "0.5226073", "0.5198325", "0.5196929", "0.51901907", "0.5189801", "0.5189801", "0.5188673", "0.5146587", "0.5122635", "0.51007515", "0.50802386", "0.50550306", "0.5026057", "0.50155663", "0.5015558", "0.5010295", "0.5008295", "0.49951133", "0.49931172", "0.49801305", "0.4974216", "0.49538863", "0.49533874", "0.4953191", "0.49441004", "0.4942437", "0.49132112", "0.4912034", "0.49076265", "0.490592", "0.49040037", "0.48970446", "0.4894679", "0.4891892", "0.48823282", "0.48818037", "0.48541453", "0.48540375", "0.4851682", "0.485111", "0.4851096", "0.48466775", "0.4841142", "0.48316216", "0.48282278", "0.48262826", "0.4823449", "0.48229608", "0.48149288", "0.48148406", "0.48034507", "0.48033947", "0.47840083", "0.47840083", "0.47822624", "0.4781226", "0.47795308", "0.4777118", "0.47739968", "0.47704092", "0.4765867", "0.476305", "0.4760713" ]
0.5322124
22
Get the manifest aieon for this parswer
public ManifestAieon getManifest();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Manifest getManifest()\n\t{\n\t\treturn manifest;\n\t}", "private Manifest getManifest() {\n Manifest manifest = new Manifest();\n Attributes attributes = manifest.getMainAttributes();\n attributes.put(Attributes.Name.MANIFEST_VERSION, \"1.0\");\n attributes.put(Attributes.Name.IMPLEMENTATION_VENDOR, \"Balahnin Sergey\");\n return manifest;\n }", "java.lang.String getManifestUrl();", "public String getManifestId()\n {\n return mManifestId;\n }", "private URL getManifestUrl() {\n\n\t\treturn new URL(VERSION_MANIFEST_URL.replace(\"%s\", \"1.7.2\"));\n\t}", "Manifest createManifest();", "public File getManifestFile() {\r\n\t\treturn manifestFile;\r\n\t}", "com.google.protobuf.ByteString\n getManifestUrlBytes();", "private void readManifest() {\n String fn = Configs.manifestLocation;\n DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();\n try {\n DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();\n Document doc = dBuilder.parse(fn);\n Node root = doc.getElementsByTagName(\"manifest\").item(0);\n String appPkg = root.getAttributes().getNamedItem(\"package\").getTextContent();\n\n Node appNode = doc.getElementsByTagName(\"application\").item(0);\n NodeList nodes = appNode.getChildNodes();\n for (int i = 0; i < nodes.getLength(); ++i) {\n Node n = nodes.item(i);\n String eleName = n.getNodeName();\n if (\"activity\".equals(eleName)) {\n try {\n NamedNodeMap m = n.getAttributes();\n String cls = m.getNamedItem(\"android:name\").getTextContent();\n if ('.' == cls.charAt(0)) {\n cls = appPkg + cls;\n }\n // record the information for activity filters\n NodeList filterNodes = n.getChildNodes();\n for (int idx = 0; idx < filterNodes.getLength(); idx++) {\n Node filterNode = filterNodes.item(idx);\n if (filterNode.getNodeName().equals(\"intent-filter\")) {\n Node actionNode = filterNode.getFirstChild();\n IntentFilter filter = new IntentFilter();\n // assume no duplicated intent filter for any activity\n while (actionNode != null) {\n if (actionNode.getNodeName().equals(\"action\")) {\n String actionName = actionNode.getAttributes().getNamedItem(\"android:name\").getTextContent();\n filter.addAction(actionName);\n } else if (actionNode.getNodeName().equals(\"category\")) {\n String category = actionNode.getAttributes().getNamedItem(\"android:name\").getTextContent();\n filter.addCategory(category);\n } else if (actionNode.getNodeName().equals(\"data\")) {\n {\n Node mTypeNode = actionNode.getAttributes().getNamedItem(\"android:mimeType\");\n String mType = mTypeNode == null ? null : mTypeNode.getTextContent();\n if (mType != null) {\n filter.addDataType(mType);\n }\n }\n {\n Node scheNode = actionNode.getAttributes().getNamedItem(\"android:scheme\");\n String scheme = scheNode == null ? null : scheNode.getTextContent();\n if (scheme != null) {\n filter.addDataScheme(scheme);\n }\n }\n {\n Node hostNode = actionNode.getAttributes().getNamedItem(\"android:host\");\n String host = hostNode == null ? null : hostNode.getTextContent();\n Node portNode = actionNode.getAttributes().getNamedItem(\"android:port\");\n String port = portNode == null ? null : portNode.getTextContent();\n if (host != null || port != null) {\n filter.addDataAuthority(host, port);\n }\n }\n {\n Node pathNode = actionNode.getAttributes().getNamedItem(\"android:path\");\n String path = pathNode == null ? null : pathNode.getTextContent();\n if (path != null) {\n filter.addDataPath(path, PatternMatcher.PATTERN_LITERAL);\n }\n }\n {\n Node pathNode = actionNode.getAttributes().getNamedItem(\"android:pathPrefix\");\n String path = pathNode == null ? null : pathNode.getTextContent();\n if (path != null) {\n filter.addDataPath(path, PatternMatcher.PATTERN_PREFIX);\n }\n }\n {\n Node pathNode = actionNode.getAttributes().getNamedItem(\"android:pathPattern\");\n String path = pathNode == null ? null : pathNode.getTextContent();\n if (path != null) {\n filter.addDataPath(path, PatternMatcher.PATTERN_SIMPLE_GLOB);\n }\n }\n }\n actionNode = actionNode.getNextSibling();\n }\n filterManager.addFilter(cls, filter);\n }\n }\n } catch (NullPointerException ne) {\n //work around for uk.co.busydoingnothing.catverbs_5.apk\n Logger.verb(\"ERROR\", \"Nullpointer Exception in readManifest, may be caused by \" +\n \"customized namespace\");\n continue;\n }\n }\n }\n } catch (Exception ex) {\n ex.printStackTrace();\n Logger.err(getClass().getSimpleName(), ex.getMessage());\n }\n }", "private static String getVersionFromManifest() {\n return ChronicleMapBuilder.class.getPackage().getImplementationVersion();\n }", "private void read_manifest(){\n dir = new File(context.getFilesDir(), folderName);\n dir.mkdir();\n manifestFile = new File(dir, \"manifest\");\n BufferedReader manifestIn = null;\n try {\n manifestIn = new BufferedReader(new FileReader(manifestFile));\n String line;\n while ((line = manifestIn.readLine()) != null) {\n String[] keyValuePair = line.split(\",\");\n pictureList.add(new KeyNamePair(keyValuePair[0], keyValuePair[1]));\n }\n } catch (FileNotFoundException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n } finally {\n if (manifestIn != null) {\n try {\n manifestIn.close();\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n }\n }", "public static ScriptManifest getManifest(Class<? extends Script> c) {\n\t\tif (c == null || !c.isAnnotationPresent(ScriptManifest.class)) {\n\t\t\treturn null;\n\t\t}\n\t\treturn c.getAnnotation(ScriptManifest.class);\n\t}", "public Manifest getManifest(final long courseId, final int flags) {\n if (!(FLAG_NON_BLOCKING == (flags & FLAG_NON_BLOCKING))) {\n assertNotOnUiThread();\n }\n\n // check to see if the manifest has been loaded already unless we are\n // forcing a reload\n if (!(FLAG_FORCE_RELOAD == (flags & FLAG_FORCE_RELOAD))) {\n synchronized (this.manifests) {\n if (this.manifests.containsKey(courseId)) {\n return this.manifests.get(courseId);\n }\n }\n }\n\n // load the manifest if we are not non-blocking (a.k.a. blocking, double\n // negatives are fun)\n if (!(FLAG_NON_BLOCKING == (flags & FLAG_NON_BLOCKING))) {\n return loadManifest(courseId, flags);\n }\n\n // just return null;\n return null;\n }", "public static String getVersionInfo() {\n return getCommonManifestEntry(getJarPathFromClassPath(getAppJarName()),null);\n }", "public String getVendor() {\n\tSystem.out.println(\"MANIFEST_INFO: \"+MANIFEST_INFO);\n\treturn MANIFEST_INFO.getImplVendor();\n\t//return this.getClass().getPackage().getImplementationVendor();\n }", "@Override\r\n public boolean includeManifest() {\r\n return true;\r\n }", "private Manifest getManifest( final File artifact ) throws IOException {\n if ( artifact.isDirectory() ) {\n // this is maybe a classes directory, try to read manifest file directly\n final File dir = new File(artifact, \"META-INF\");\n if ( !dir.exists() || !dir.isDirectory() ) {\n return null;\n }\n final File mf = new File(dir, \"MANIFEST.MF\");\n if ( !mf.exists() || !mf.isFile() ) {\n return null;\n }\n final InputStream is = new FileInputStream(mf);\n try {\n return new Manifest(is);\n } finally {\n try { is.close(); } catch (final IOException ignore) { }\n }\n }\n JarFile file = null;\n try {\n file = new JarFile( artifact );\n return file.getManifest();\n } finally {\n if ( file != null ) {\n try { file.close(); } catch ( final IOException ignore ) {}\n }\n }\n }", "public String outputImageManifests() {\n return this.outputImageManifests;\n }", "public AccManifest accManifest() {\n if (_accManifest == null)\n _accManifest = new AccManifest(this, Keys.BCC_MANIFEST_FROM_ACC_MANIFEST_ID_FK);\n\n return _accManifest;\n }", "public String getApp();", "public Manifest() {}", "String getPackager();", "public String getManifestList(boolean isEconomy) {\n if (individualReservedList.size() + groupReservedList.size() == 0) {\n return \"Manifest is Empty\";\n }\n ArrayList<Passenger> manifestList = airplane.getAllReservedPas(isEconomy);\n\n StringBuilder manifestInfo = addServiceClassHeader(isEconomy);\n\n for (Passenger pas : manifestList) {\n Seat s = pas.getSeat();\n String seatInfo = String.format(\"%d%c: %s \", s.getRow(),\n convertSeatColToString(s.getCol()), pas.getName());\n manifestInfo.append(seatInfo);\n manifestInfo.append(\"\\n\");\n }\n manifestInfo.append(\"\\n\");\n return manifestInfo.toString();\n }", "private String[] getManifestPermissions(Activity paramActivity) {\n }", "java.lang.String getManifestHashAlgorithm();", "private static String getVersion() throws IOException {\n URL res = Main.class.getResource(\"/META-INF/MANIFEST.MF\");\n if(res!=null) {\n Manifest manifest = new Manifest(res.openStream());\n String v = manifest.getMainAttributes().getValue(\"Implementation-Version\");\n if(v!=null)\n return v;\n }\n return \"?\";\n }", "public IMApplicationInfo getIMApplicationInfo(){\n\t\treturn this.getApplicationContextFactory().getApplicationContext().getRequestContext().getIMApplicationInfo();\n\t}", "ListenableFuture<CacheResult> fetchManifest(RuleKey manifestKey, LazyPath downloadedManifest);", "public Object getApplication(String attibuteName) {\n return servletRequest.getServletContext().getAttribute(attibuteName);\n }", "@Test\n public void getManifestPropertiesTest() throws ApiException {\n String deviceTypeId = null;\n String version = null;\n // ManifestPropertiesEnvelope response = api.getManifestProperties(deviceTypeId, version);\n\n // TODO: test validations\n }", "org.apache.xmlbeans.XmlAnyURI xgetManifestHashAlgorithm();", "ManifestIdentifier getIdentifier();", "private final Bundle m1027e() {\n try {\n ApplicationInfo applicationInfo = this.f979b.getPackageManager().getApplicationInfo(this.f980c, 128);\n if (applicationInfo != null && applicationInfo.metaData != null) {\n return applicationInfo.metaData;\n }\n f978a.mo34139a(\"App has no applicationInfo or metaData\", new Object[0]);\n return null;\n } catch (PackageManager.NameNotFoundException unused) {\n f978a.mo34143d(\"App is not found in PackageManager\", new Object[0]);\n return null;\n }\n }", "private ArrayList<App> getApps() {\n PackageManager manager = getPackageManager();\n Intent i = new Intent(Intent.ACTION_MAIN, null);\n i.addCategory(Intent.CATEGORY_LAUNCHER);\n\n List<ResolveInfo> availableActivities = manager.queryIntentActivities(\n i, 0);\n ArrayList<App> temp = new ArrayList<App>();\n for (ResolveInfo ri : availableActivities) {\n App app = new App();\n app.packname = ri.activityInfo.packageName;\n app.appName = app.packname\n .substring(app.packname.lastIndexOf(\".\") + 1);\n app.icon = ri.activityInfo.loadIcon(manager);\n temp.add(app);\n }\n return temp;\n }", "private Manifest loadManifest(final long courseId, final int flags) {\n synchronized (getLock(this.locks, courseId)) {\n // short-circuit if the manifest has been loaded and we aren't\n // forcing a reload\n if (!(FLAG_FORCE_RELOAD == (flags & FLAG_FORCE_RELOAD))) {\n synchronized (this.manifests) {\n if (this.manifests.containsKey(courseId)) {\n return this.manifests.get(courseId);\n }\n }\n }\n\n // fetch the course object, we don't care about resources\n final Course course = this.dao.findCourse(courseId, false);\n\n // short-circuit if we don't have a valid course\n if (course == null) {\n storeManifest(courseId, null);\n return null;\n }\n\n // load the manifest from disk if it exists\n final String manifestName = course.getManifestFile();\n if (manifestName != null) {\n try {\n // return a parsed manifest\n final Manifest manifest = parseManifestFile(manifestName);\n storeManifest(courseId, manifest);\n return manifest;\n } catch (final FileNotFoundException e) {\n // file is missing\n } catch (final XmlPullParserException e) {\n // xml is invalid, delete the manifest and continue\n context.deleteFile(manifestName);\n } catch (final IOException e) {\n // error reading file, not sure what happened so do\n // nothing\n LOG.error(\"error reading manifest\", e);\n return null;\n }\n\n // we had an error loading the existing manifest, so reset\n // it on the course object\n course.setManifestFile(null);\n course.setManifestVersion(0);\n this.dao.update(course, PROJECTION_MANIFEST);\n }\n\n // manifest doesn't exist, try downloading it\n if (!(FLAG_DONT_DOWNLOAD == (flags & FLAG_DONT_DOWNLOAD))) {\n return downloadManifest(courseId, null, flags);\n }\n\n return null;\n }\n }", "public String getLauncher() {\n return launcher;\n }", "public void editManifest() {\n byte[] arrby;\n AXmlEditor aXmlEditor = new AXmlEditor();\n File file = new File((Object)Environment.getExternalStorageDirectory() + \"/BIKINAPLIKASI/tmp/AndroidManifest.xml\");\n try {\n this.copyManifest(file);\n }\n catch (IOException iOException) {\n iOException.printStackTrace();\n }\n ArrayList arrayList = new ArrayList();\n File file2 = new File((Object)Environment.getExternalStorageDirectory() + \"/BIKINAPLIKASI/tmp\", \"AndroidManifest.xml\");\n try {\n byte[] arrby2;\n arrby = arrby2 = FileUtil.readFile(file2);\n }\n catch (IOException iOException) {\n iOException.printStackTrace();\n arrby = null;\n }\n try {\n aXmlEditor.read((List<String>)arrayList, arrby);\n }\n catch (IOException iOException) {\n iOException.printStackTrace();\n }\n String string = StringUtils.join((Collection<String>)arrayList, \"\\n\").replaceFirst(\"namatoko\", this.username).replace((CharSequence)\"namatoko.situsbelanja.com\", (CharSequence)(this.username + \".situsbelanja.com\")).replace((CharSequence)\"namatoko.olshp.com\", (CharSequence)(this.username + \".olshp.com\")).replace((CharSequence)\"domainbikinaplikasionlineshop.com\", (CharSequence)this.dataPref.getWebsite()).replace((CharSequence)\"Nama Toko\", (CharSequence)this.namaaplikasi).replaceFirst(\"com.bikinaplikasi.onlineshop\", \"com.bikinaplikasi.\" + this.username).replaceFirst(\"com.bikinaplikasi.onlineshop.permission.C2D_MESSAGE\", \"com.bikinaplikasi.\" + this.username + \".permission.C2D_MESSAGE\").replaceFirst(\"com.bikinaplikasi.onlineshop.google_measurement_service\", \"com.bikinaplikasi.\" + this.username + \".google_measurement_service\").replace((CharSequence)\"android:debuggable=\\\"true\\\"\", (CharSequence)\"android:debuggable=\\\"false\\\"\").replace((CharSequence)\"4.47\", (CharSequence)(this.versi + \".0\"));\n Integer.parseInt((String)this.versi);\n ByteArrayOutputStream byteArrayOutputStream = new ByteArrayOutputStream();\n File file3 = new File((Object)Environment.getExternalStorageDirectory() + \"/BIKINAPLIKASI/tmp\", \"AndroidManifest.xml\");\n try {\n this.out = new FileOutputStream(file3);\n }\n catch (FileNotFoundException fileNotFoundException) {\n fileNotFoundException.printStackTrace();\n }\n try {\n aXmlEditor.write(string.toString(), (OutputStream)byteArrayOutputStream);\n }\n catch (IOException iOException) {\n iOException.printStackTrace();\n }\n try {\n this.out = new FileOutputStream(file3);\n }\n catch (FileNotFoundException fileNotFoundException) {\n fileNotFoundException.printStackTrace();\n }\n try {\n this.out.write(byteArrayOutputStream.toByteArray());\n return;\n }\n catch (IOException iOException) {\n iOException.printStackTrace();\n return;\n }\n }", "@NotNull\n @ApiModelProperty(example = \"y1234456789c\", required = true, value = \"The info file is an python file containing the package metadata.\")\n public String getManifestFile() {\n return manifestFile;\n }", "@Test\n public void destiny2GetDestinyManifestTest() {\n InlineResponse20033 response = api.destiny2GetDestinyManifest();\n\n // TODO: test validations\n }", "public String getMainClassName() throws IOException {\n URL u = new URL(\"jar\", \"\", url + \"!/\");\n JarURLConnection uc = (JarURLConnection)u.openConnection();\n Attributes attr = uc.getMainAttributes();\n return attr != null ? attr.getValue(Attributes.Name.MAIN_CLASS) : null;\n }", "public BccpManifest bccpManifest() {\n if (_bccpManifest == null)\n _bccpManifest = new BccpManifest(this, Keys.BCC_MANIFEST_TO_BCCP_MANIFEST_ID_FK);\n\n return _bccpManifest;\n }", "public ApplicationInfo getApplicationInfo() {\n return getActivityInfo().applicationInfo;\n }", "public String getProducerApplication();", "String getExtra();", "public PackageManager getPackageManager() {\r\n\t\treturn mPm;\r\n\t}", "@Test\n public void getLatestManifestPropertiesTest() throws ApiException {\n String deviceTypeId = null;\n // ManifestPropertiesEnvelope response = api.getLatestManifestProperties(deviceTypeId);\n\n // TODO: test validations\n }", "public com.atomgraph.linkeddatahub.apps.model.Application getApplication()\n {\n return (com.atomgraph.linkeddatahub.apps.model.Application)getContainerRequestContext().getProperty(LAPP.Application.getURI());\n }", "public static String getCommonManifestEntry(String jarFile, String tag) {\n try {\n\t \tJarFile jarfile = new JarFile(jarFile,false);\n\t \tManifest mf = jarfile.getManifest();\n\t \tString v = null;\n\t \tif (tag == null) {\n\t \t for (Iterator iter = mf.getAttributes(\"common\").keySet().iterator(); iter.hasNext();) {\n Object key = iter.next();\n v=v==null?\"\":v;\n v = v+\"\\n\"+key+\": \"+mf.getAttributes(\"common\").get(key);\n }\n\t \t} else {\n\t \t v = mf.getAttributes(\"common\").getValue(tag);\n\t \t}\n\t \tif (v!=null) return v;\n\t\t} catch (Exception e) {\n\t\t System.out.println(\"jarfile = \"+jarFile);\n\t\t\te.printStackTrace();\n\t\t}\n \treturn \"N/A\";\n }", "TaskManifest loadManifest(Path path) throws IOException {\n return TaskManifest.load(getFileSystem(), path);\n }", "public Optional<ApplicationVersion> application() { return application; }", "private Element createManifestEntry (String location, URI format,\n\t\tboolean mainEntry)\n\t{\n\t\tElement element = new Element (\"content\", Utils.omexNs);\n\t\telement.setAttribute (\"location\", location);\n\t\telement.setAttribute (\"format\", format.toString ());\n\t\tif (mainEntry)\n\t\t\telement.setAttribute (\"master\", \"\" + mainEntry);\n\t\treturn element;\n\t}", "protected ApplicationDescriptor getNextApplicationDescriptor0(int jamId) throws BuildException {\n ApplicationDescriptor descriptor = new ApplicationDescriptor();\n BufferedReader fileReader = null;\n try {\n String urlString = getNextAppUrlString;\n if (jamId >= 0) {\n urlString += \"/\" + jamId;\n }\n URL url = new URL(urlString);\n fileReader = new BufferedReader(new InputStreamReader(url.openStream()));\n String line;\n while ((line = fileReader.readLine()) != null) {\n Reader lineReader = new StringReader(line);\n StringBuffer keyBuffer = new StringBuffer();\n StringBuffer valueBuffer = new StringBuffer();\n int read;\n while (((read = lineReader.read()) != -1) && (read != ':')) {\n keyBuffer.append((char) read);\n }\n if (read == ':') {\n while (((read = lineReader.read()) != -1)) {\n valueBuffer.append((char) read);\n }\n String key = keyBuffer.toString().trim();\n String value = valueBuffer.toString().trim();\n if (key.equals(\"Application-Name\")) {\n descriptor.applicationName = value;\n } else if (key.equals(\"JAR-File-URL\") || key.equals(\"MIDlet-Jar-URL\")) {\n descriptor.jarFileUrlString = value;\n } else if (key.equals(\"JAR-File-Size\") || key.equals(\"MIDlet-Jar-Size\")) {\n descriptor.jarFileSize = Integer.parseInt(value);\n } else if (key.equals(\"Main-Class\")) {\n descriptor.mainClassName = value;\n } else if(key.equals(\"MIDlet-1\")) {\n descriptor.midlet1Line = value;\n StringTokenizer tokenizer = new StringTokenizer(value);\n String lastToken = null;\n while (tokenizer.hasMoreTokens()) {\n lastToken = tokenizer.nextToken();\n }\n if (lastToken != null) {\n lastToken = lastToken.trim();\n }\n descriptor.mainClassName = lastToken;\n } else if (key.equals(\"Use-Once\")) {\n descriptor.useOnce = value.equals(\"yes\");\n }\n }\n }\n suceededAtLeastOnceToGetNextApplicationDescriptor = true;\n return descriptor;\n } catch (IOException e) {\n throw new BuildException(\"unable to get application descriptor: \" + e.getMessage());\n } finally {\n if (fileReader != null) {try {fileReader.close();} catch (IOException e) {}};\n fileReader = null;\n }\n }", "public String getExecutable();", "public static Bundle m3a(Intent intent) {\n return intent.getBundleExtra(\"al_applink_data\");\n }", "public String getApplication() {\r\n return application;\r\n }", "String getExecutable();", "public static ApkManifest getApkManifest(String apkfilePath) throws ParserException{\n \tInputStream androidManifestInputStream = null;\n \t\n \tFile file = new File(apkfilePath);\n\t\tZipFile zipFile = null;\n\t\ttry {\n\t\t\tzipFile = new ZipFile(file);\n\t\t} catch (IOException ioe) {\n\t\t\tthrow new ZipUtilsException(\"Failed to open zip file : \" + file.getName() + \" : \"+ ioe.getMessage(), ioe);\n\t\t}\n\n \ttry {\n \t\tandroidManifestInputStream = ZipUtils.getInputStreamByEntryName(zipFile, \"AndroidManifest.xml\");\n\t\t\treturn getApkManifest(androidManifestInputStream);\n\t\t} catch (Exception e) {\n\t\t\tthrow new ParserException(\"Failed to parse apk manifest : \" + e.getMessage(), e);\n\t\t} finally {\n\t\t\tif (androidManifestInputStream!=null) {\n\t\t\t\ttry {\n\t\t\t\t\tandroidManifestInputStream.close();\n\t\t\t\t} catch (IOException ioe) {\n\t\t\t\t\tthrow new ParserException(\"Failed to close apk manifest stream : \" + ioe.getMessage(), ioe);\n\t\t\t\t}\n\t\t\t}\n\t\t\ttry {\n\t\t\t\tzipFile.close();\n\t\t\t} catch (IOException ioe) {\n\t\t\t\tthrow new ParserException(\"Failed to close apk zip file : \" + ioe.getMessage(), ioe);\n\t\t\t}\n\t\t}\n }", "String getArch();", "private ArrayList<PInfo> getPackages() {\n\t\tArrayList<PInfo> apps = getInstalledApps(false); /* false = no system packages */\n\t\tfinal int max = apps.size();\n\t\tfor (int i=0; i<max; i++) {\n\t\t\tapps.get(i).getIcon();\n\t\t}\n\t\treturn apps;\n\t}", "@Nonnull\n public static UBL23WriterBuilder <ManifestType> manifest ()\n {\n return UBL23WriterBuilder.create (ManifestType.class);\n }", "public App getWorldAppearance() {\n return worldAppearance;\n }", "public Launcher getLauncher(){\n \treturn mLauncher;\n }", "private String getLauncherPackageName() {\n // Create launcher Intent\n final Intent intent = new Intent(Intent.ACTION_MAIN);\n intent.addCategory(Intent.CATEGORY_HOME);\n\n // Use PackageManager to get the launcher package name\n PackageManager pm = InstrumentationRegistry.getContext().getPackageManager();\n ResolveInfo resolveInfo = pm.resolveActivity(intent, PackageManager.MATCH_DEFAULT_ONLY);\n return resolveInfo.activityInfo.packageName;\n }", "private static Map<String, ManifestItem> manifestItems(final File rootDir, final Document opfDoc) throws IOException {\n\n Map<String, ManifestItem> files = Maps.newLinkedHashMap();\n\n for(Element element : opfDoc.select(\"manifest > item\")) {\n String href = element.attr(\"href\").trim();\n if(href.isEmpty()) {\n continue;\n } else if(href.startsWith(\"/\")) {\n href = href.substring(1);\n }\n\n File file = new File(rootDir, href);\n if(!file.exists()) {\n throw new IOException(String.format(\"Missing file, '%s'\", file.getAbsolutePath()));\n }\n\n String id = element.attr(\"id\").trim();\n if(id.isEmpty()) {\n throw new IOException(String.format(\"Missing id for, '%s'\", file.getAbsolutePath()));\n }\n\n String mediaType = element.attr(\"media-type\").trim();\n\n files.put(id, new ManifestItem(id, href, file, mediaType));\n }\n\n return files;\n }", "@Override\n public OutputStream openOutputStream() throws IOException {\n final ByteArrayOutputStream baos = new ByteArrayOutputStream();\n return new FilterOutputStream(baos){\n @Override\n public void close() throws IOException {\n writeManifestJarEntry(readManifest(baos));\n }\n };\n }", "private void writeManifest(HttpServletRequest request,\n HttpServletResponse response) throws IOException {\n setNoCache(response);\n if (!isManifestEnabled(request)) {\n response.setStatus(HttpServletResponse.SC_NOT_FOUND);\n return;\n }\n if (errorParam.get(request) != null) {\n addManifestErrorCookie(response);\n response.setStatus(HttpServletResponse.SC_NO_CONTENT);\n return;\n }\n \n try {\n setPreloads();\n \n String originalPath = (String)request.getAttribute(AuraResourceServlet.ORIG_REQUEST_URI);\n if(originalPath != null){\n String currentManifestUrl = AuraServlet.getManifest();\n if (!originalPath.equals(currentManifestUrl)) {\n response.setStatus(HttpServletResponse.SC_NOT_FOUND);\n deleteManifestCookie(response);\n return;\n }\n }\n \n String serverLastMod = Long.toString(getManifestLastMod());\n Cookie cookie = getManifestCookie(request);\n if(cookie != null){\n if (MANIFEST_ERROR.equals(cookie.getValue())) {\n response.setStatus(HttpServletResponse.SC_NOT_FOUND);\n deleteManifestCookie(response);\n return;\n }\n }\n \n Map<String, Object> attribs = Maps.newHashMap();\n attribs.put(\"lastMod\", serverLastMod);\n StringWriter sw = new StringWriter();\n for(String s:AuraServlet.getStyles()){\n sw.write(s);\n sw.write('\\n');\n }\n for(String s:AuraServlet.getScripts()){\n sw.write(s);\n sw.write('\\n');\n }\n attribs.put(\"resourceURLs\", sw.toString());\n DefinitionService definitionService = Aura.getDefinitionService();\n InstanceService instanceService = Aura.getInstanceService();\n DefDescriptor<ComponentDef> tmplDesc = definitionService.getDefDescriptor(\"ui:manifest\", ComponentDef.class);\n Component tmpl = instanceService.getInstance(tmplDesc, attribs);\n Aura.getRenderingService().render(tmpl, response.getWriter());\n } catch (Exception e) {\n Aura.getExceptionAdapter().handleException(e);\n // Can't throw exception here: to set manifest OBSOLETE\n response.setStatus(HttpServletResponse.SC_NOT_FOUND);\n }\n }", "public MauiApplication getApplication ()\n\t{\n\t\treturn application;\n\t}", "public org.thethingsnetwork.management.proto.HandlerOuterClass.Application getApplication(org.thethingsnetwork.management.proto.HandlerOuterClass.ApplicationIdentifier request);", "public String getPackaging();", "public List<ArchiveEntry> getMainEntries ()\n\t{\n\t\treturn mainEntries;\n\t}", "DocumentFragment getInstallationDescriptorExtension();", "public static String getBuiltBy() {\r\n return getJarInfo(\"Built-By\");\r\n }", "@XmlElement(name = \"gav\")\n public Gav getGav() throws IOException {\n JarFile jarFile = new JarFile(this.getJarFile());\n try {\n Enumeration<JarEntry> entries = jarFile.entries();\n // For all Entries\n while (entries.hasMoreElements()) {\n JarEntry jarEntry = (JarEntry) entries.nextElement();\n // look for pom.properties\n if (jarEntry.getName().endsWith(\"pom.properties\")) {\n Gav gav = extractGavInformation(jarFile, jarEntry);\n return gav;\n\n }\n }\n return null;\n } finally {\n jarFile.close();\n }\n }", "public static String obtenerversionApp(Context context){\n String respuesta=\"\";\n try {\n PackageInfo packageInfo=context.getPackageManager().getPackageInfo(context.getPackageName(),0);\n respuesta=packageInfo.versionName;\n } catch (PackageManager.NameNotFoundException e) {\n e.printStackTrace();\n }\n return respuesta;\n }", "private appR getApp() throws JAXBException, IOException {\n synchronized (application) {\r\n appR App = (appR) application.getAttribute(\"App\");\r\n if (App == null) {\r\n App = new appR();\r\n App.setFilePath(application.getRealPath(\"WEB-INF/Listings.xml\"));\r\n application.setAttribute(\"App\", App);\r\n }\r\n return App;\r\n }\r\n }", "public String getAppName();", "public String getApplication() {\r\n\t\treturn application;\r\n\t}", "public GetManifestHandler(final Vertx aVertx, final JsonObject aConfig) {\n super(aVertx, aConfig);\n }", "public static String getAppPlatfrom() {\n\n\t\treturn \"android\";\n\t}", "String getSingleLinkerScriptFile();", "String getArchiveMechanism();", "public static MIDLetParamsApp getApplication() {\n return Application.getInstance(MIDLetParamsApp.class);\n }", "public String getPackageName() {\n return mAppEntry.info.packageName;\n }", "public App getLocalAppearance() {\n return localAppearance;\n }", "public String\n getProgram() \n {\n if(PackageInfo.sOsType == OsType.Windows) \n return (\"winimage.exe\");\n return super.getProgram();\n }", "public com.google.common.util.concurrent.ListenableFuture<org.thethingsnetwork.management.proto.HandlerOuterClass.Application> getApplication(\n org.thethingsnetwork.management.proto.HandlerOuterClass.ApplicationIdentifier request);", "protected Intent getIntentForChangePresenter() {\n \t// Destino: Presentador H\n \tIntent intent = new Intent(PresentadorV_main.this,\n \t\t\tPresentadorH_main.class);\n\t\tintent.setAction(INTENT_ACTION);\t\n\t\t// Guarda en el intent el contenido de la searchview\n\t\t// ojo: es tipo CharSequence\t\t\n\t\tintent.putExtra(INTENT_CONTENT_WISEARCH, wi_search.getQuery());\n \treturn intent;\n }", "Application getApplication();", "void setManifestHashAlgorithm(java.lang.String manifestHashAlgorithm);", "public void getintent() {\n Intent intent = this.getIntent();\n acceptDetailsModel = (AcceptDetailsModel) intent.getSerializableExtra(\"menu_item\");\n }", "public List<String> getUsedPermissions() {\n final List<String> result = new LinkedList<String>();\n for (final Element child : manifestElement.getChildren(ELEMENT_USES_PERMISSION)) {\n final String permission = child.getAttributeValue(ATTRIBUTE_NAME);\n if (permission != null) {\n result.add(permission);\n }\n }\n\n return result;\n }", "public BccManifest() {\n this(DSL.name(\"bcc_manifest\"), null);\n }", "static Application getAppDescriptor(String appDir, boolean annotationProcessing) \n throws IASDeploymentException\n {\n\t\ttry {\n FileArchive archive = new FileArchive();\n archive.open(appDir);\n\n ApplicationArchivist archivist = new ApplicationArchivist();\n archivist.setAnnotationProcessingRequested(annotationProcessing);\n archivist.setXMLValidation(false);\n\n return (Application) archivist.open(archive);\n\t\t} catch(Throwable t) {\n\t\t\tthrow new IASDeploymentException(t);\n\t\t}\n\t}", "java.lang.String getAppName();", "java.lang.String getAppName();", "java.lang.String getAppName();", "public ApplicationInfo getApplicationInfo() {\n return null;\n }", "static Application getAppDescriptor(String appDir) throws IASDeploymentException\n {\n return getAppDescriptor(appDir, false);\n\t}", "public void setManifestVersion() {\n\t\tSharedPreferences.Editor editor = sp.edit();\n\t\teditor.putString(VERSION_KEY, thisVersion);\n\t\teditor.commit();\n\t}", "public static String getLauncherClassName() {\n Context context = RuntimeEnvironment.application;\n Intent homeIntent = new Intent(Intent.ACTION_MAIN)\n .addCategory(Intent.CATEGORY_HOME)\n .setPackage(context.getPackageName())\n .addFlags(Intent.FLAG_ACTIVITY_NEW_TASK);\n\n List<ResolveInfo> launchers = context.getPackageManager()\n .queryIntentActivities(homeIntent, 0);\n if (launchers.size() != 1) {\n return null;\n }\n return launchers.get(0).activityInfo.name;\n }" ]
[ "0.73589575", "0.7293171", "0.7145607", "0.66441625", "0.65772235", "0.6405273", "0.6339626", "0.6170449", "0.6109734", "0.5943118", "0.5845792", "0.57066417", "0.57035446", "0.56722766", "0.5631006", "0.56211394", "0.5585725", "0.55165213", "0.5432907", "0.5424064", "0.53846407", "0.53846157", "0.5377659", "0.53484106", "0.53480643", "0.5322615", "0.5269638", "0.52572954", "0.5229424", "0.5220536", "0.5210266", "0.51814127", "0.5158256", "0.5140853", "0.51184344", "0.5065319", "0.50488704", "0.5033435", "0.5020293", "0.50158054", "0.50075525", "0.49991918", "0.49792454", "0.49718997", "0.49613574", "0.4956014", "0.4925139", "0.48826322", "0.4880184", "0.4874819", "0.48694408", "0.48582983", "0.4858117", "0.4808787", "0.4801392", "0.480093", "0.48003992", "0.47897094", "0.4748991", "0.47489536", "0.4737077", "0.47358808", "0.47319573", "0.4725392", "0.47196513", "0.46946454", "0.46939707", "0.46861246", "0.46838364", "0.46797296", "0.46703413", "0.46671963", "0.46485615", "0.46484715", "0.46440834", "0.46413428", "0.46403775", "0.46377555", "0.46334872", "0.46208575", "0.46205232", "0.46113417", "0.4595591", "0.45817947", "0.45784876", "0.4570011", "0.45653033", "0.45646372", "0.45613664", "0.45592073", "0.45557395", "0.45494708", "0.45461118", "0.45424244", "0.45424244", "0.45424244", "0.45409745", "0.45297348", "0.45274788", "0.45180762" ]
0.85296744
0
Get the persistence object that reads and writes the content
public IPersistence<T> getPersistence();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public abstract FHIRPersistence getPersistenceImpl() throws Exception;", "private static PersistenceSession getPersistenceSession() {\n return NakedObjectsContext.getPersistenceSession();\n }", "public abstract int getPersistence();", "OStorage getStorage();", "public FooPersistence getFooPersistence() {\n return fooPersistence;\n }", "public LibroPersistence getLibroPersistence() {\n return libroPersistence;\n }", "public ResourcePersistence getResourcePersistence() {\n return resourcePersistence;\n }", "private static PersistenceManager getPersistenceManager() {\n\t\treturn PMF.get().getPersistenceManager();\n\t}", "public IDfPersistentObject getObject() {\n\t\treturn object;\n\t}", "public Persistence() {}", "protected abstract Serializable getEntity();", "public interface PersistenceImplementor {\n public boolean persistObject(Object object);\n\n public boolean persistAllObjects(Object[] objects);\n\n public Object loadObject(String objectID);\n\n public Object[] loadAllObjects();\n}", "public T getSavedObject() {\n if (dbObjects.length == 0) {\n throw new MongoException(\"No objects to return\");\n }\n return getSavedObjects().get(0);\n }", "public Object getObject() {\n\t\ttry {\n\t\t\tByteArrayInputStream istream = new ByteArrayInputStream(mStoredObjectArray);\n\t\t\tObjectInputStream p;\n\t\t\tObject toReturn = null;\n\t\t\tif (mIsJython) {\n\t\t\t} else {\n\t\t\t\t\n\t\t\t\ttoReturn = null;\n\t\t\t}\n\t\t\tistream.close();\n\t\t\treturn toReturn;\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t\treturn null;\n\t\t}\n\t}", "public void loadPersistence() {\n\t\tFile file = new File(\"data.txt\");\n\t\tif (file.length() == 0) { // no persistent data to use\n\t\t\treturn;\n\t\t}\n\t\tdeserializeFile(file);\n\t\tloadPersistentSettings();\n\t}", "@Override\n public FileObject getPersistenceXml()\n {\n FileObject location = locationProvider.getLocation();\n if (location == null)\n {\n return null;\n }\n return location.getFileObject(\"persistence.xml\"); // NOI18N\n \n }", "public Class<T> getPersistenceClass()\n \t{\n \t\treturn this.persistenceClass;\n \t}", "public EncogPersistedObject readObject(final String name) {\r\n\r\n\t\t// did we find the object?\r\n\t\tif (advance(name)) {\r\n\t\t\tfinal String objectType = this.in.getTag().getName();\r\n\t\t\tfinal Persistor persistor = PersistorUtil\r\n\t\t\t\t\t.createPersistor(objectType);\r\n\r\n\t\t\tif (persistor == null) {\r\n\t\t\t\tthrow new PersistError(\"Do not know how to load: \" + objectType);\r\n\t\t\t}\r\n\t\t\treturn persistor.load(this.in);\r\n\t\t} else {\r\n\t\t\treturn null;\r\n\t\t}\r\n\t}", "public interface Persistence<T> {\n public T retrieve(String path) throws IOException, BadFormatException;\n public void save(T object, String path) throws IOException;\n}", "public Serializable getObject() throws OpenwireException {\n if (object == null && getContent() != null) {\n try {\n Buffer content = getContent();\n InputStream is = new ByteArrayInputStream(content);\n if (isCompressed()) {\n is = new InflaterInputStream(is);\n }\n DataInputStream dataIn = new DataInputStream(is);\n ClassLoadingAwareObjectInputStream objIn = new ClassLoadingAwareObjectInputStream(dataIn);\n try {\n object = (Serializable)objIn.readObject();\n } catch (ClassNotFoundException ce) {\n throw new OpenwireException(\"Failed to build body from content. Serializable class not available to broker. Reason: \" + ce, ce);\n } finally {\n dataIn.close();\n }\n } catch (IOException e) {\n throw new OpenwireException(\"Failed to build body from bytes. Reason: \" + e, e);\n }\n }\n return this.object;\n }", "public JournalArticlePersistence getJournalArticlePersistence() {\n\t\treturn journalArticlePersistence;\n\t}", "public Object getPersistedObject(Class myClass) {\n return this.queryDatabaseMasterSingle(myClass);\n }", "public UserPersistence getUserPersistence() {\n return userPersistence;\n }", "public UserPersistence getUserPersistence() {\n return userPersistence;\n }", "public UserPersistence getUserPersistence() {\n return userPersistence;\n }", "public UserPersistence getUserPersistence() {\n return userPersistence;\n }", "@GET\n @Produces(\"application/xml\")\n public StorageConverter get() {\n return new StorageConverter(dao.retrieveById(id), context.getAbsolutePath());\n }", "Object getDB();", "public final PersistenceManager getPersistenceManager (){\n//\t\tSystem.out.println (\"returning persistent manager for properties \"+\tthis._dataStoreEnvironment.getDataStoreProperties ());\n\t\treturn this.pm;\n\t}", "public DataStorage getDataStorage();", "protected PersistenceStructureService getPersistenceStructureService() {\r\n return persistenceStructureService;\r\n }", "public WorkerPersistence getWorkerPersistence() {\n return workerPersistence;\n }", "public UserPersistence getUserPersistence() {\n\t\treturn userPersistence;\n\t}", "public UserPersistence getUserPersistence() {\n\t\treturn userPersistence;\n\t}", "public UserPersistence getUserPersistence() {\n\t\treturn userPersistence;\n\t}", "public UserPersistence getUserPersistence() {\n\t\treturn userPersistence;\n\t}", "public AssetEntryPersistence getAssetEntryPersistence() {\n\t\treturn assetEntryPersistence;\n\t}", "public Object getPersisted(String key) {\r\n\t\treturn getPersistenceMap().get(key);\r\n\t}", "synchronized static PersistenceHandler getInstance() {\n return singleInstance;\n }", "SequencerStorage getSequencerStorage();", "private PersistenceManager getPersistenceManager() {\n if(pmf==null) {\n getFacetHolder().getServiceInjector().injectServicesInto(this);\n }\n return pmf.getPersistenceManagerFactory().getPersistenceManager();\n }", "T getObject() {\n\t\t\treturn data;\n\t\t}", "public DataPersistence() {\n storage = new HashMap<>();\n idCounter = 0;\n }", "public void updatePersistence() {\n\t\tFile file = new File(\"data.txt\");\n\t\tserializeToFile(file);\n\t\tupdatePersistentSettings();\n\t}", "@Generated(hash = 1042367595)\npublic Documento getDocumento() {\n Long __key = this.documentoId;\n if (documento__resolvedKey == null\n || !documento__resolvedKey.equals(__key)) {\n final DaoSession daoSession = this.daoSession;\n if (daoSession == null) {\n throw new DaoException(\"Entity is detached from DAO context\");\n }\n DocumentoDao targetDao = daoSession.getDocumentoDao();\n Documento documentoNew = targetDao.load(__key);\n synchronized (this) {\n documento = documentoNew;\n documento__resolvedKey = __key;\n }\n }\n return documento;\n}", "public interface PersistenceFactory {\n /* Fields */\n\n /**\n * The property name for all classes stored at the column:row level to introspect the entity that contains the\n * properties persisted in a row's columns\n */\n String CLASS_PROPERTY = \"___class\";\n\n /* Misc */\n\n /**\n * Deletes columns by name from column family\n *\n * @param columnFamily the column family\n * @param key the key\n * @param columns the columns to be deleted by name\n */\n void deleteColumns(String columnFamily, String key, String... columns);\n\n /**\n * Executes a query\n *\n * @param expectedResult the result expected from the query execution\n * @param query the query\n * @param <T> the result type\n * @return the result\n */\n <T> T executeQuery(Class<T> expectedResult, Query query);\n\n /**\n * @param entityClass the class\n * @param key the id\n * @param <T> the entity type\n * @return an entity from the data store looked up by its id\n */\n <T> T get(Class<T> entityClass, String key);\n\n /**\n * Fetch a map of columns and their values\n *\n * @param columnFamily the column family\n * @param key the column family key\n * @param reversed if the order should be reversed\n * @param columns the column names\n * @return a map of columns and their values\n */\n Map<String, ByteBuffer> getColumns(String columnFamily, String key, boolean reversed, String... columns);\n\n /**\n * Fetch a map of columns and their values\n *\n * @param columnFamily the column family\n * @param key the column family key\n * @param limit of columns\n * @param reversed if the order should be reversed\n * @param fromColumn from column\n * @param toColumn to column\n * @return a map of columns and their values\n */\n Map<String, ByteBuffer> getColumns(String columnFamily, String key, int limit, boolean reversed, String fromColumn, String toColumn);\n\n /**\n * @return the default consistency level\n */\n ConsistencyLevel getDefaultConsistencyLevel();\n\n /**\n * @return the default keyspace\n */\n String getDefaultKeySpace();\n\n /**\n * @param entityClass the class type for this instance\n * @param <T> the type of class to be returned\n * @return an instance of this type after transformation of its accessors to notify the persistence context that there are ongoing changes\n */\n <T> T getInstance(Class<T> entityClass);\n\n /**\n * Obtains an entity key\n *\n * @param entity the entity\n * @return the key\n */\n String getKey(Object entity);\n\n /**\n * The list of managed class by this factory\n *\n * @return The list of managed class by this factory\n */\n List<Class<?>> getManagedClasses();\n\n /**\n * Get a list of entities given a query\n *\n * @param type the type of objects to expect back\n * @param query the query\n * @param <T> the result type\n * @return the list of entities\n */\n <T> List<T> getResultList(Class<T> type, Query query);\n\n /**\n * Get a single result from a CQL query\n *\n * @param type the type of objects to expect back\n * @param query the query\n * @param <T> the entity type\n * @return the resulting entity\n */\n <T> T getSingleResult(Class<T> type, Query query);\n\n /**\n * Inserts columns based on a map representing keys with properties and their corresponding values\n *\n * @param columnFamily the column family\n * @param key the column family key\n * @param keyValuePairs the map with keys and values\n */\n void insertColumns(String columnFamily, String key, Map<String, Object> keyValuePairs);\n\n /**\n * Entry point method to persist and arbitrary list of objects into the datastore\n *\n * @param entities the entities to be persisted\n */\n <T> void persist(T... entities);\n\n /**\n * @param entities the entities to be removed from the data store\n */\n <T> void remove(T... entities);\n \n /**\n * return cluster\n */\n Cluster getCluster(); \n}", "public ODatabaseDocumentTx getOrCreateDB();", "public Persistence() {\n\t\tconn = dbConnection();\n\t}", "DataStore getDataStore ();", "public Serializable readObject(){\n Serializable loadedObject = null;\n try {\n FileInputStream fileIn = new FileInputStream(name);\n ObjectInputStream in = new ObjectInputStream(fileIn);\n loadedObject = (Serializable) in.readObject();\n in.close();\n fileIn.close();\n System.out.println(\"Data loaded from: \"+ name);\n } \n catch (IOException i) {\n System.out.println(\"File not found.\");\n } \n catch (ClassNotFoundException c) {\n System.out.println(\"Class not found\");\n }\n return loadedObject;\n }", "public interface IPersistence\n{\n\t/**\n\t * When overridden in a child class, determines whether data exists which\n\t * can be loaded\n\t * @pre (none)\n\t * @post (none)\n\t * @return True if data can be loaded. Otherwise, false.\n\t */\n\tboolean canLoadData();\n\n\t/**\n\t * When overridden in a child class, loads all data from specified store to\n\t * the passed Inventory\n\t * @pre inventory is not null. storeName refers to a valid data store.\n\t * @post inventory's original contents have been cleared and replaced with\n\t * the data from the specified data store\n\t * @throws SerializerException\n\t */\n\tvoid loadData() throws SerializerException;\n\n\t/**\n\t * When overridden in a child class, saves all data from the Inventory with\n\t * the specified name\n\t * @pre storeName is a valid string for the system we are saving to\n\t * @post The passed Inventory has been saved under the passed name\n\t * @throws SerializerException\n\t */\n\tvoid saveData() throws SerializerException;\n}", "LockStorage getLockStorage();", "OsType getObjectStore();", "public JournalArticleResourcePersistence getJournalArticleResourcePersistence() {\n\t\treturn journalArticleResourcePersistence;\n\t}", "<T> Serializable save(T persistentObject);", "public PersistenceStructureService getPersistenceStructureService() {\r\n return persistenceStructureService;\r\n }", "public static DataManager getInstance()\n\t{\n\t\tDataManager pManager = null;\n\t\tObject pObject = UiStorage.getEntity(DataManager.class);\n\t\tif ( null == pObject )\n\t\t{\n\t\t\tpManager = new DataManager();\n\t\t\tUiStorage.setEntity(pManager);\n\t\t}\n\t\telse\n\t\t{\n\t\t\tpManager = (DataManager)pObject;\n\t\t}\n\t\t\n\t\treturn pManager;\n\t}", "public Storable readStorable() throws IOException {\n Storable storable;\n String s = readString();\n\n if (s.equals(\"NULL\"))\n return null;\n\n if (s.equals(\"REF\")) {\n int ref = readInt();\n return (Storable) retrieve(ref);\n }\n\n storable = (Storable) makeInstance(s);\n map(storable);\n storable.read(this);\n return storable;\n }", "@Override\n\tpublic byte[] get()\n\t{\n\t\tif (isInMemory())\n\t\t{\n\t\t\tif (cachedContent == null)\n\t\t\t{\n\t\t\t\tcachedContent = dfos.getData();\n\t\t\t}\n\t\t\treturn cachedContent;\n\t\t}\n\n\t\tFile file = dfos.getFile();\n\n\t\ttry\n\t\t{\n\t\t\treturn Files.readBytes(file);\n\t\t}\n\t\tcatch (IOException e)\n\t\t{\n\t\t\tlog.debug(\"failed to read content of file: \" + file.getAbsolutePath(), e);\n\t\t\treturn null;\n\t\t}\n\t}", "public Partie charger() {\n Partie partie = new Partie(0,\"pseudo\");\n try {\n FileInputStream fileStream = new FileInputStream(\"savePartie\");\n ObjectInputStream objectStream = new ObjectInputStream(fileStream);\n partie.setPseudo((String)objectStream.readObject());\n partie.niveau = (int)objectStream.readObject();\n objectStream.close();\n fileStream.close();\n } catch ( IOException | ClassNotFoundException e) {\n e.printStackTrace();\n }\n return partie;\n }", "public Blob getContentBlob() {\n return Hibernate.createBlob(this.content);\n }", "T makePersistent(T entity);", "public JournalReader read() {\n return new JournalReader(this);\n }", "public Object getObject() {\n return getObject(null);\n }", "PersistentDataHolder getDataHolder();", "public Document obtainEditableInstance()\n throws WorkflowException, MappingException, RepositoryException, RemoteException;", "public Object getOriginalObject() {\n // Compute the original for unit of work writes.\n if ((originalObject == null) && getSession().isUnitOfWork() && (getQuery() != null) && (getQuery().isObjectLevelModifyQuery())) {\n setOriginalObject(((UnitOfWorkImpl)getSession()).getOriginalVersionOfObject(getSource()));\n }\n return originalObject;\n }", "private static Interaction loadInteraction() {\n File f = new File(\"./save_data\");\n if (f.exists()) {\n try {\n FileInputStream fs = new FileInputStream(f);\n ObjectInputStream os = new ObjectInputStream(fs);\n return (Interaction) os.readObject();\n } catch (FileNotFoundException e) {\n System.out.println(\"file not found\");\n System.exit(0);\n } catch (IOException e) {\n System.out.println(e);\n System.exit(0);\n } catch (ClassNotFoundException e) {\n System.out.println(\"class not found\");\n System.exit(0);\n }\n }\n /* In the case no Editor has been saved yet, we return a new one. */\n System.exit(0);\n return new Interaction();\n }", "Serializable getContent();", "public LocalRichPersistence getLocalRichPersistence() {\n\t\treturn localRichPersistence;\n\t}", "protected Object readResolve() {\n return getInstance();\n }", "public PersistentDataContainer getPersistentDataContainer ( ) {\n\t\treturn extract ( handle -> handle.getPersistentDataContainer ( ) );\n\t}", "public BarPersistence getBarPersistence() {\n return barPersistence;\n }", "protected abstract Object getTransactionObject() throws TransactionInfrastructureException;", "public Object getObject()\n {\n initialize();\n\n if (_invariant)\n return _cachedValue;\n\n return resolveProperty();\n }", "public Storage getStorage() {\n return this.storage;\n }", "public Object getObject()\n\t{\n\t\treturn transactionManager;\n\t}", "javax.management.ObjectName getPersistenceManager();", "public Object read(Object object) {\n EntityManager em = getEntityManager();\n em.getTransaction().begin();\n Object result = null;\n try {\n result = em.find(object.getClass(), \"id\");\n LOG.debug(\"Found \" + object);\n } catch (Exception e) {\n LOG.error(\"Could not find Object\", e);\n } finally {\n em.close();\n }\n return result;\n }", "public com.hps.july.persistence.StoragePlaceAccessBean getStorage() {\n\treturn storage;\n}", "public SQLiteDatabase getSqliteObjectWithReadable(){\n return getReadableDatabase();\n }", "private EntityManager getEM() {\n\t\tif (emf == null || !emf.isOpen())\n\t\t\temf = Persistence.createEntityManagerFactory(PUnit);\n\t\tEntityManager em = threadLocal.get();\n\t\tif (em == null || !em.isOpen()) {\n\t\t\tem = emf.createEntityManager();\n\t\t\tthreadLocal.set(em);\n\t\t}\n\t\treturn em;\n\t}", "public Boolean persistent();", "protected Object readResolve() {\r\n\t\treturn getInstance();\r\n\t}", "protected Object readResolve() {\r\n\t\treturn getInstance();\r\n\t}", "private Object writeReplace () {\n return new java.io.Serializable () {\n /** serial version UID */\n static final long serialVersionUID=-3874531277726540941L;\n\n private void writeObject (ObjectOutputStream oos) throws IOException {\n TopManager.getDefault ().getRepository ().writeExternal (oos);\n }\n\n private void readObject (ObjectInputStream ois)\n throws IOException, ClassNotFoundException {\n TopManager.getDefault ().getRepository ().readExternal (ois);\n }\n\n /** @return the default pool */\n public Object readResolve () {\n return TopManager.getDefault ().getRepository ();\n }\n };\n }", "public interface IPersistentObject extends IGUIDObject {\n\t\n /**\n * Gets a representation of the object.\n * \n * @return the object's state\n */\n IData reify();\n \n /**\n * Initialises the object.\n * \n * @param data the new state\n * @param pid the new PID\n * @param guid the new GUID\n */\n void initialise( IData data, IPID pid, IGUID guid );\n \n /**\n * Records the object's current state.\n * \n * @throws PersistenceException if the object's state could not be recorded\n */\n void persist() throws PersistenceException;\n \n /**\n * Gets the PID referring to the object's most recently recorded persistent state.\n * \n * @return the PID for the object's most recent persistent state\n */\n IPID getPID();\n}", "public interface IPersistencia<E> {\r\n void openInput(String fileName) throws Exception;\r\n\r\n void closeInput() throws Exception;\r\n\r\n void openOutput(String fileName) throws Exception;\r\n\r\n void closeOutput() throws Exception;\r\n\r\n void write(E obj) throws Exception;\r\n\r\n E read() throws Exception;\r\n}", "public abstract org.omg.CORBA.Object read_Object();", "public Object load() {\n return null;\n }", "public interface Conexao {\n\t/**\n\t * Realiza a gravação dem um Object afim de se obter a persistencia dele\n\t * \n\t * @param obj\n\t * o Object que sera gravado\n\t */\n\tpublic void write(Object obj);\n\n\t/**\n\t * Realiza a leitura de um Object\n\t * \n\t * @return O Object lido, ou null se nao for encontrado\n\t */\n\tpublic Object read();\n\n}", "public Object read();", "public byte[] getBytes()\n {\n try { return getRepo().newObjectReader().open(_entry.getObjectId()).getBytes(); }\n catch(Exception e) { throw new RuntimeException(e); }\n }", "public ItemPublicacaoPersistence getItemPublicacaoPersistence() {\n\t\treturn itemPublicacaoPersistence;\n\t}", "ContentStorage getContentStorage(TypeStorageMode mode) throws FxNotFoundException;", "public AccountStorage getStore() {\n\t\t@SuppressWarnings(\"resource\")\n\t\tApplicationContext springContext = new AnnotationConfigApplicationContext(AccountServerConfig.class);\n return (AccountStorage) springContext.getBean(\"getStorage\");\n\t}", "@Override\n\tpublic void read(Object entidade) {\n\t\t\n\t}", "public interface IDBStorableModel {\n\n\t/**\n\t * Saves the model to db\n\t * \n\t * @param db\n\t * @return\n\t */\n\tpublic void store(DBConnection db) throws IOException;\n\t\n}", "@Override\n\tpublic AttachmentHibernateDAO getAttachmentDAO() {\n\t\treturn (AttachmentHibernateDAO)instantiateDAO(AttachmentHibernateDAO.class);\n\t}", "public interface DBStorage {\n \n /**\n * Get the name of the storage vendor (DB vendor name)\n *\n * @return name of the storage vendor (DB vendor name)\n */\n String getStorageVendor();\n \n /**\n * Can this storage handle the requested database?\n *\n * @param dbm database meta data\n * @return if storage can handle the requested database\n */\n boolean canHandle(DatabaseMetaData dbm);\n \n /**\n * Get the ContentStorage singleton instance\n *\n * @param mode used storage mode\n * @return ContentStorage singleton instance\n * @throws FxNotFoundException if no implementation was found\n */\n ContentStorage getContentStorage(TypeStorageMode mode) throws FxNotFoundException;\n \n /**\n * Get the EnvironmentLoader singleton instance\n *\n * @return EnvironmentLoader singleton instance\n */\n EnvironmentLoader getEnvironmentLoader();\n \n /**\n * Get the SequencerStorage singleton instance\n *\n * @return SequencerStorage singleton instance\n */\n SequencerStorage getSequencerStorage();\n \n /**\n * Get the TreeStorage singleton instance\n *\n * @return TreeStorage singleton instance\n */\n TreeStorage getTreeStorage();\n \n /**\n * Get the LockStorage singleton instance\n *\n * @return LockStorage singleton instance\n */\n LockStorage getLockStorage();\n \n /**\n * Get a data selector for a sql search\n *\n * @param search current SqlSearch to operate on\n * @return data selector\n * @throws FxSqlSearchException on errors\n */\n DataSelector getDataSelector(SqlSearch search) throws FxSqlSearchException;\n \n /**\n * Get a data filter for a sql search\n *\n * @param con an open and valid connection\n * @param search current SqlSearch to operate on\n * @return DataFilter\n * @throws FxSqlSearchException on errors\n */\n DataFilter getDataFilter(Connection con, SqlSearch search) throws FxSqlSearchException;\n \n /**\n * Get the CMIS SQL Dialect implementation\n *\n * @param environment environment\n * @param contentEngine content engine in use\n * @param query query\n * @param returnPrimitives return primitives?\n * @return CMIS SQL Dialect implementation\n */\n SqlDialect getCmisSqlDialect(FxEnvironment environment, ContentEngine contentEngine, CmisSqlQuery query, boolean returnPrimitives);\n \n /**\n * Get the database vendor specific Boolean expression\n *\n * @param flag the flag to get the expression for\n * @return database vendor specific Boolean expression for <code>flag</code>\n */\n String getBooleanExpression(boolean flag);\n \n /**\n * Get the boolean <code>true</code> expression string for the database vendor\n *\n * @return the boolean <code>true</code> expression string for the database vendor\n */\n String getBooleanTrueExpression();\n \n /**\n * Get the boolean <code>false</code> expression string for the database vendor\n *\n * @return the boolean <code>false</code> expression string for the database vendor\n */\n String getBooleanFalseExpression();\n \n /**\n * Escape reserved words properly if needed\n *\n * @param query the query to escape\n * @return escaped query\n */\n String escapeReservedWords(String query);\n \n /**\n * Get a database vendor specific \"IF\" function\n *\n * @param condition the condition to check\n * @param exprtrue expression if condition is true\n * @param exprfalse expression if condition is false\n * @return database vendor specific \"IF\" function\n */\n String getIfFunction(String condition, String exprtrue, String exprfalse);\n \n /**\n * Get the database vendor specific operator to query regular expressions\n *\n * @param column column to match\n * @param regexp regexp to match the column against\n * @return database vendor specific operator to query regular expressions\n */\n String getRegExpLikeOperator(String column, String regexp);\n \n /**\n * Get the database vendor specific statement to enable or disable referential integrity checks.\n * When in a transaction, be sure to check {@link #isDisableIntegrityTransactional()}\n * since not all databases support this in a transactional context.\n *\n * @param enable enable or disable checks?\n * @return database vendor specific statement to enable or disable referential integrity checks\n */\n String getReferentialIntegrityChecksStatement(boolean enable);\n \n /**\n * Return true if calling {@link #getReferentialIntegrityChecksStatement(boolean)} is possible\n * in a transactional context.\n *\n * @return true if calling {@link #getReferentialIntegrityChecksStatement(boolean)} is possible\n * in a transactional context\n */\n boolean isDisableIntegrityTransactional();\n \n /**\n * Get the sql code of the statement to fix referential integrity when removing selectlist items\n *\n * @return sql code of the statement to fix referential integrity when removing selectlist items\n */\n String getSelectListItemReferenceFixStatement();\n \n /**\n * Get a database vendor specific timestamp of the current time in milliseconds as Long\n *\n * @return database vendor specific timestamp of the current time in milliseconds as Long\n */\n String getTimestampFunction();\n \n /**\n * Get a database vendor specific concat statement\n *\n * @param text array of text to concatenate\n * @return concatenated text statement\n */\n String concat(String... text);\n \n /**\n * Get a database vendor specific concat_ws statement\n *\n * @param delimiter the delimiter to use\n * @param text array of text to concatenate\n * @return concatenated text statement\n */\n String concat_ws(String delimiter, String... text);\n \n /**\n * If a database needs a \" ... from dual\" to generate valid queries, it is returned here\n *\n * @return from dual (or equivalent) if needed\n */\n String getFromDual();\n \n /**\n * Get databas evendor specific limit statement\n *\n * @param hasWhereClause does the query already contain a where clause?\n * @param limit limit\n * @return limit statement\n */\n String getLimit(boolean hasWhereClause, long limit);\n \n /**\n * Get database vendor specific limit/offset statement\n *\n * @param hasWhereClause does the query already contain a where clause?\n * @param limit limit\n * @param offset offset\n * @return limit/offset statement\n */\n String getLimitOffset(boolean hasWhereClause, long limit, long offset);\n \n /**\n * Get database vendor specific limit/offset statement using the specified variable name\n *\n * @param var name of the variable to use\n * @param hasWhereClause does the query already contain a where clause?\n * @param limit limit\n * @param offset offset\n * @return limit/offset statement\n */\n String getLimitOffsetVar(String var, boolean hasWhereClause, long limit, long offset);\n \n /**\n * Get the statement to get the last content change timestamp\n *\n * @param live live version included?\n * @return statement to get the last content change timestamp\n */\n String getLastContentChangeStatement(boolean live);\n \n /**\n * Format a date to be used in a query condition (properly escaped)\n *\n * @param date the date to format\n * @return formatted date\n */\n String formatDateCondition(Date date);\n \n /**\n * Correctly escape a flat storage column if needed\n *\n * @param column name of the column\n * @return escaped column (if needed)\n */\n String escapeFlatStorageColumn(String column);\n \n /**\n * Returns true if the SqlError is a foreign key violation.\n *\n * @param exc the exception\n * @return true if the SqlError is a foreign key violation\n */\n boolean isForeignKeyViolation(Exception exc);\n \n /**\n * Returns true if the given exception was caused by a query timeout.\n *\n * @param e the exception to be examined\n * @return true if the given exception was caused by a query timeout\n * @since 3.1\n */\n boolean isQueryTimeout(Exception e);\n \n /**\n * Does the database rollback a connection if it encounters a constraint violation? (eg Postgres does...)\n *\n * @return database rollbacks a connection if it encounters a constraint violation\n */\n boolean isRollbackOnConstraintViolation();\n \n /**\n * Returns true if the SqlError is a unique constraint violation.\n *\n * @param exc the exception\n * @return true if the SqlError is a unique constraint violation\n */\n boolean isUniqueConstraintViolation(Exception exc);\n \n /**\n * Returns true if the given SqlException indicates a deadlock.\n *\n * @param exc the exception\n * @return true if the given SqlException indicates a deadlock.\n * @since 3.1\n */\n boolean isDeadlock(Exception exc);\n \n /**\n * When accessing the global configuration - does the config table has to be prefixed with the schema?\n * (eg in postgres no schemas are supported for JDBC URL's hence it is not required)\n *\n * @return access to configuration tables require the configuration schema to be prepended\n */\n boolean requiresConfigSchema();\n \n /**\n * Get a connection to the database using provided parameters and (re)create the database and/or schema\n *\n * @param database name of the database\n * @param schema name of the schema\n * @param jdbcURL JDBC connect URL\n * @param jdbcURLParameters optional JDBC URL parameters\n * @param user name of the db user\n * @param password password\n * @param createDB create the database?\n * @param createSchema create the schema?\n * @param dropDBIfExist drop the database if it exists?\n * @return an open connection to the database with the schema set as default\n * @throws Exception on errors\n */\n Connection getConnection(String database, String schema, String jdbcURL, String jdbcURLParameters, String user, String password, boolean createDB, boolean createSchema, boolean dropDBIfExist) throws Exception;\n \n /**\n * Initialize a configuration schema\n *\n * @param con an open and valid connection to the database\n * @param schema the schema to create\n * @param dropIfExist drop the schema if it exists?\n * @return success\n * @throws Exception on errors\n */\n boolean initConfiguration(Connection con, String schema, boolean dropIfExist) throws Exception;\n \n /**\n * Initialize a division\n *\n * @param con an open and valid connection to the database\n * @param schema the schema to create\n * @param dropIfExist drop the schema if it exists?\n * @return success\n * @throws Exception on errors\n */\n boolean initDivision(Connection con, String schema, boolean dropIfExist) throws Exception;\n \n /**\n * Export all data of a division to an OutputStream as ZIP\n *\n * @param con an open and valid connection to the database to be exported\n * @param out OutputStream that will be used to create the zip file\n * @throws Exception on errors\n */\n void exportDivision(Connection con, OutputStream out) throws Exception;\n \n /**\n * Import a complete division from a zip stream\n *\n * @param con an open and valid connection\n * @param zip zip archive that contains an exported divison\n * @throws Exception on errors\n */\n void importDivision(Connection con, ZipFile zip) throws Exception;\n }" ]
[ "0.7124204", "0.6764136", "0.66909647", "0.65289074", "0.6510063", "0.62832147", "0.62776595", "0.6145867", "0.6141428", "0.61304766", "0.611309", "0.6089469", "0.6014759", "0.6013596", "0.6007122", "0.5991224", "0.59850276", "0.59640664", "0.5961079", "0.5901131", "0.58913356", "0.5881262", "0.58749634", "0.58749634", "0.58749634", "0.58749634", "0.58691573", "0.58540493", "0.5838078", "0.582151", "0.5814146", "0.58019966", "0.5780075", "0.5780075", "0.5780075", "0.5780075", "0.5770469", "0.56981474", "0.5689924", "0.5687044", "0.56611234", "0.5656255", "0.56505674", "0.56467485", "0.5644147", "0.56409687", "0.56326544", "0.559323", "0.55767286", "0.5565974", "0.5563087", "0.5559189", "0.555634", "0.5541397", "0.5534487", "0.5501834", "0.55015194", "0.54983145", "0.5498038", "0.5495902", "0.5478959", "0.54764056", "0.54722834", "0.5466428", "0.5456707", "0.5451363", "0.54353195", "0.5432336", "0.542358", "0.54155874", "0.54080236", "0.540166", "0.53917253", "0.5388987", "0.5385833", "0.53857833", "0.5377931", "0.5375471", "0.53570014", "0.5356683", "0.53489953", "0.5348218", "0.53393483", "0.5336984", "0.5336984", "0.53355896", "0.53328544", "0.5329659", "0.53279513", "0.5319994", "0.5319285", "0.53171825", "0.5316231", "0.53003657", "0.52977526", "0.5292185", "0.52623385", "0.525994", "0.52586645", "0.525567" ]
0.7230267
0
If true, the parser only parses descriptors. This can be very efficient if the descriptor info is contained, for instance in a file or entry name. In such a case, the content of the file or entry does not need to be parsed
public boolean isDescriptorOnly();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public final boolean isValidDescriptor(String desc) {\n return getValidDescriptors().contains(desc);\n }", "boolean supports(Object descriptor);", "public void setDescriptorOnly( boolean descriptorOnly );", "internal boolean hasDataDescriptor (){\r\n\t\t\treturn _hasDataDescriptor;\r\n\t\t}", "public void addFieldDescriptor(XMLFieldDescriptor descriptor) {\n\n\t boolean added = false;\n\n NodeType nodeType = descriptor.getNodeType();\n switch(nodeType.getType()) {\n case NodeType.ATTRIBUTE:\n if (!attributeDescriptors.contains(descriptor)) {\n attributeDescriptors.add(descriptor);\n added = true;\n }\n break;\n case NodeType.TEXT:\n contentDescriptor = descriptor;\n added = true;\n break;\n default:\n if (!elementDescriptors.contains(descriptor)) {\n elementDescriptors.add(descriptor);\n added = true;\n }\n break;\n }\n if (added) {\n\t descriptor.setContainingClassDescriptor( this );\n\t }\n\n }", "public boolean hasDescription() {\n return fieldSetFlags()[1];\n }", "public boolean canBuildParser() {\r\n return isParser(getFormatter());\r\n }", "public boolean hasDescription() {\n return fieldSetFlags()[4];\n }", "public boolean isDescargable() {\n return descargable;\n }", "public boolean hasDESCRIPTION() {\n return fieldSetFlags()[1];\n }", "protected void parseDescriptors(ByteArrayInputStream stream) throws EOFException\n {\n int byteCount = EASMessage.parseUnsignedShort(stream) & 0x3FF;\n int length;\n int tag;\n\n for (int d = 0; byteCount > 0; byteCount -= (length + 2), ++d)\n {\n tag = EASMessage.parseUnsignedByte(stream); // present in every\n // descriptor\n length = EASMessage.parseUnsignedByte(stream); // present in every\n // descriptor\n byte[] value = parseByteArray(stream, length); // varies in every\n // descriptor\n\n switch (tag)\n {\n case EASDescriptor.INBAND_DETAILS_CHANNEL: // [SCTE 18] 5.1.1\n {\n if (isOutOfBandAlert())\n {\n if (log.isInfoEnabled())\n {\n log.info(formatLogMessage(\"Descriptor[\" + d + \"]: Disregarding IB Details Channel Descriptor in OOB alert\"));\n }\n continue;\n }\n\n try\n {\n int qamFrequency = ConversionUtil.rfChannelToFrequency(value[2] & 0xFF);\n int programNumber = (value[3] & 0xFF) << 8 | (value[4] & 0xFF);\n OcapLocator locator = createIBDetailsChannelLocator(qamFrequency, programNumber);\n if (null == this.m_detailsChannelLocator)\n { // retain first IB details channel descriptor only\n this.m_detailsChannelLocator = locator;\n }\n }\n catch (ArrayIndexOutOfBoundsException e) // TODO:\n // alternative: log\n // a warning &\n // continue w/next\n // descriptor\n {\n throw new EOFException(\n \"Corrupt section table - IB details channels descriptor improperly encoded\");\n }\n catch (IllegalArgumentException e)\n {\n if (log.isWarnEnabled())\n {\n log.warn(formatLogMessage(\"Descriptor[\" + d + \"]: Disregarding invalid IB details channel - \" + e.getMessage()));\n }\n }\n catch (InvalidLocatorException e)\n {\n if (log.isWarnEnabled())\n {\n log.warn(formatLogMessage(\"Descriptor[\" + d + \"]: Disregarding invalid IB details channel - \" + e.getMessage()));\n }\n }\n\n continue;\n }\n case EASDescriptor.INBAND_EXCEPTION_CHANNELS: // [SCTE 18]\n // 5.1.2\n {\n if (isOutOfBandAlert())\n {\n if (log.isInfoEnabled())\n {\n log.info(formatLogMessage(\"Descriptor[\" + d + \"]: Disregarding IB Exception Channels Descriptor in OOB alert\"));\n }\n continue;\n }\n\n int exceptionChannelCount = value[0] & 0xFF;\n this.m_exceptions.ensureCapacity(this.m_exceptions.size() + exceptionChannelCount);\n\n for (int i = 0, j = 1; i < exceptionChannelCount; ++i, j += 3)\n {\n try\n {\n byte rfChannel = value[j];\n int programNumber = (value[j + 1] & 0xFF) << 8 | (value[j + 2] & 0xFF);\n this.m_exceptions.add(new EASInBandExceptionDescriptor(rfChannel, programNumber));\n }\n catch (ArrayIndexOutOfBoundsException e) // TODO:\n // alternative:\n // log a\n // warning &\n // continue\n // w/next\n // descriptor\n {\n throw new EOFException(\n \"Corrupt section table - IB exception channels descriptor improperly encoded\");\n }\n catch (IllegalArgumentException e)\n {\n if (log.isWarnEnabled())\n {\n log.warn(formatLogMessage(\"Descriptor[\" + d + \"]: Disregarding invalid IB exception channel - \"\n + e.getMessage()));\n }\n }\n }\n\n continue;\n }\n case EASDescriptor.AUDIO_FILE: // [SCTE 18] 5.1.3\n {\n int numberOfAudioSources = value[0] & 0xFF;\n this.m_audioFileSources.ensureCapacity(this.m_audioFileSources.size() + numberOfAudioSources);\n\n for (int i = 0, j = 1; i < numberOfAudioSources; ++i)\n {\n int loopLength = value[j++] & 0xFF;\n parseAudioFileSource(new ByteArrayInputStream(value, j, loopLength));\n j += loopLength;\n }\n\n this.m_audioFileSources.trimToSize();\n continue;\n }\n case EASDescriptor.ATSC_PRIVATE_INFORMATION: // [SCTE 18] 5.1.4\n {\n this.m_audioDescriptorAvailable = true;\n break;\n }\n default:\n {\n if (tag < EASDescriptor.USER_PRIVATE) // [SCTE 18] 5.1.4\n // and 7.1-13\n {\n if (log.isWarnEnabled())\n {\n log.warn(formatLogMessage(\"Descriptor[\" + d + \"] Disregarding unrecognized tag:<0x\" + Integer.toHexString(tag)\n + \">\"));\n }\n continue;\n }\n\n this.m_audioDescriptorAvailable = true;\n }\n }\n\n this.m_descriptors.add(new EASDescriptor(tag, value));\n }\n\n this.m_descriptors.trimToSize();\n }", "public boolean isSetDesc()\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return get_store().find_attribute_user(DESC$10) != null;\r\n }\r\n }", "boolean isSetDesc();", "@Override\n\t\t\t\tpublic boolean hasParser() {\n\t\t\t\t\treturn true;\n\t\t\t\t}", "boolean hasDescribe();", "public boolean checkDescription() {\n int size = description.length();\n return size >= 1 && size <= 256;\n }", "boolean hasDescription();", "boolean hasDescription();", "boolean hasDescription();", "boolean getDesc();", "public boolean hasFdset() {\n return ((bitField0_ & 0x00000010) != 0);\n }", "@Override\r\n public boolean isDescendent(final FileName descendent) {\r\n return isDescendent(descendent, NameScope.DESCENDENT);\r\n }", "private Descriptor parseDescriptorLine(String line) {\n\t\tDescriptor result = new Descriptor();\n\t\t// set descriptor name\n\t\tString descName = parseDescrName(line);\n\t\tresult.setName(descName);\n\t\tString dom = descName.substring(0, 6);\n\t\tString[] tokens = line.split(\"\\\\s+\");\n\t\t// 226-253;184-204\n\t\tString[] tokensA = tokens[1].split(\";\");\n\t\tInteger start1 = Integer.valueOf(tokensA[0].replaceFirst(\"-\\\\d+\", \"\")); // 226\n\t\tInteger start2 = Integer.valueOf(tokensA[1].replaceFirst(\"-\\\\d+\", \"\")); // 184\n\t\t// 0_0:-5_-8\n\t\ttokens[4] = tokens[4].replaceAll(\"0_0:\", \"\");\n\t\tString[] shifts = tokens[4].split(\"_\");\n\t\tint shift1 = Integer.valueOf(shifts[0]);\n\t\tint shift2 = Integer.valueOf(shifts[1]);\n\t\tstart1 = start1 - shift1;\n\t\tstart2 = start2 - shift2;\n\n\t\tint end1 = start1 + tokens[2].length() - 1;\n\t\tint end2 = start2 + tokens[3].length() - 1;\n\n\t\tString seq1;\n\t\tString seq2;\n\t\ttry {\n\t\t\tseq1 = fastaSeqs.get(dom).substring(start1, end1 + 1);\n\t\t\tseq2 = fastaSeqs.get(dom).substring(start2, end2 + 1);\n\t\t} catch (IndexOutOfBoundsException e) {\n\t\t\treturn null;\n\t\t}\n\t\tString SSeq1;\n\t\tString SSeq2;\n\t\ttry {\n\t\t\tSSeq1 = SS_Seqs.get(dom).substring(start1, end1 + 1);\n\t\t\tSSeq2 = SS_Seqs.get(dom).substring(start2, end2 + 1);\n\t\t} catch (IndexOutOfBoundsException e) {\n\t\t\treturn null;\n\t\t}\n\n\t\tString startAddr1 = hashResMapInt2Str.get(dom).get(start1);\n\t\tString endAddr1 = hashResMapInt2Str.get(dom).get(end1);\n\n\t\tString startAddr2 = hashResMapInt2Str.get(dom).get(start2);\n\t\tString endAddr2 = hashResMapInt2Str.get(dom).get(end2);\n\n\t\tSegment segm1 = new Segment();\n\t\tsegm1.setStart(startAddr1);\n\t\tsegm1.setStartFastaNo(start1);\n\t\tsegm1.setEnd(endAddr1);\n\t\tsegm1.setEndFastaNo(end1);\n\t\tsegm1.setSeq(seq1);\n\t\tsegm1.setSSSeq(SSeq1);\n\n\t\tSegment segm2 = new Segment();\n\t\tsegm2.setStart(startAddr2);\n\t\tsegm2.setStartFastaNo(start2);\n\t\tsegm2.setEnd(endAddr2);\n\t\tsegm2.setEndFastaNo(end2);\n\t\tsegm2.setSeq(seq2);\n\t\tsegm2.setSSSeq(SSeq2);\n\n\t\tList<Segment> segments = new ArrayList<Segment>();\n\t\t// switch the order of segments\n\t\tsegments.add(segm2);\n\t\tsegments.add(segm1);\n\t\tresult.setSegments(segments);\n\t\ttry{\n\t\t\tresult.setFoldAstral(hashFold.get(dom));\n\t\t} catch(NullPointerException e){\n\t\t\t// do nothing i this case\n\t\t}\n\t\treturn result;\n\t}", "public boolean hasDescribe() {\n return ((bitField0_ & 0x00000008) == 0x00000008);\n }", "@java.lang.Override\n public boolean hasFdset() {\n return fdset_ != null;\n }", "public boolean hasContent() {\n return fieldSetFlags()[1];\n }", "public void setDescriptor(Descriptor inDescriptor);", "public boolean hasDescribe() {\n return ((bitField0_ & 0x00000008) == 0x00000008);\n }", "public interface DescriptorAccess extends DescriptorRead\n{\n /**\n * Sets Descriptor (full replace).\n *\n * @param inDescriptor replaces the Descriptor associated with the\n * component implementing this interface. If the inDescriptor is invalid for the\n * type of Info object it is being set for, an exception is thrown. If the\n * inDescriptor is null, then the Descriptor will revert to its default value\n * which should contain, at a minimum, the descriptor name and descriptorType.\n *\n * @see #getDescriptor\n */\n public void setDescriptor(Descriptor inDescriptor);\n}", "public boolean hasInfo() {\n return fieldSetFlags()[6];\n }", "public boolean hasDEALPNTFEATID() {\n return fieldSetFlags()[4];\n }", "@Override\n\tpublic Boolean canParse(String fileName) {\n\t\treturn fileName.contains(\"gene_association.\") && !fileName.endsWith(\".gz\");\n\t}", "public abstract List<String> getValidDescriptors();", "public static boolean processConnector(ConnectorDescriptor desc, ConnectorConfigProperty ep, Class declaringClass) {\n if(desc.getResourceAdapterClass().equals(declaringClass.getName())){\n if (!(isConfigDefined(desc.getConfigProperties(), ep))) {\n desc.addConfigProperty(ep);\n }\n if(!desc.getConfigPropertyProcessedClasses().contains(declaringClass.getName())){\n processParent(declaringClass.getSuperclass(), desc.getConfigProperties());\n desc.addConfigPropertyProcessedClass(declaringClass.getName());\n }\n //indicate that the config-property is processed\n return true;\n }else{\n //indicate that the config-property is not processed and need to be processed during post-processing\n return false;\n }\n }", "public boolean hasSPARQLDESCpreds() {\n return fieldSetFlags()[9];\n }", "boolean hasInfoType();", "private boolean isDescriptionInDocGeneratorResponse(DocumentGeneratorResponse response) {\n\n if (StringUtils.isBlank(response.getDescription())) {\n Map<String, Object> logMap = new HashMap<>();\n logMap.put(LOG_MESSAGE_KEY,\n \"The description has not been in the Document Generator Response\");\n LOGGER.error(LOG_DOC_GENERATOR_RESPONSE_INVALID_MESSAGE_KEY, logMap);\n\n return false;\n }\n return true;\n }", "@Override\r\n public boolean isDescendent(final FileName descendent, final NameScope scope) {\r\n if (!descendent.getRootURI().equals(getRootURI())) {\r\n return false;\r\n }\r\n return checkName(getPath(), descendent.getPath(), scope);\r\n }", "public boolean hasDEALPNTFEATLNID() {\n return fieldSetFlags()[0];\n }", "public void setDescargable(boolean descargable) {\n this.descargable = descargable;\n }", "@Override\n public boolean needsFormat()\n {\n return delegates.stream().anyMatch(SplittableInputSource::needsFormat);\n }", "public boolean hasContent() {\n return fieldSetFlags()[8];\n }", "public boolean hasInfos(){\n return infos != null;\n }", "@DSComment(\"Package priviledge\")\n @DSBan(DSCat.DEFAULT_MODIFIER)\n @DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2013-12-30 12:59:08.680 -0500\", hash_original_method = \"4B0B8276597CEA521E1E338B4AADD471\", hash_generated_method = \"9283ED1C2044F4178961436920D7FF12\")\n \nstatic ImageDescriptor parse(byte[] rawData, int valueIndex) {\n ImageDescriptor d = new ImageDescriptor();\n try {\n d.width = rawData[valueIndex++] & 0xff;\n d.height = rawData[valueIndex++] & 0xff;\n d.codingScheme = rawData[valueIndex++] & 0xff;\n\n // parse image id\n d.imageId = (rawData[valueIndex++] & 0xff) << 8;\n d.imageId |= rawData[valueIndex++] & 0xff;\n // parse offset\n d.highOffset = (rawData[valueIndex++] & 0xff); // high byte offset\n d.lowOffset = rawData[valueIndex++] & 0xff; // low byte offset\n\n d.length = ((rawData[valueIndex++] & 0xff) << 8 | (rawData[valueIndex++] & 0xff));\n } catch (IndexOutOfBoundsException e) {\n CatLog.d(\"ImageDescripter\", \"parse; failed parsing image descriptor\");\n d = null;\n }\n return d;\n }", "protected boolean isStructureKnown() {\n\t\ttry {\n\t\t\treturn ((OpenableElementInfo) getElementInfo()).isStructureKnown();\n\t\t} catch (Exception e) {\n\t\t\treturn false;\n\t\t}\n\t}", "public boolean hasDEALPNTFEATLNCMNTTXT() {\n return fieldSetFlags()[9];\n }", "public boolean canBuildFormatter() {\r\n return isFormatter(getFormatter());\r\n }", "public String getDescriptor() {\n/* 218 */ return this.desc;\n/* */ }", "boolean hasExplicitContentDetectionConfig();", "public boolean hasDescription() {\n return ((bitField0_ & 0x00000004) == 0x00000004);\n }", "public boolean hasDescription() {\n return ((bitField0_ & 0x00000004) == 0x00000004);\n }", "@Override\r\n public boolean hasContentModified(ContainerUser context)\r\n {\n return hasDescriptorPropertyChanged(ReportDescriptor.Prop.json.name());\r\n }", "boolean hasCharacteristicDescription();", "private boolean parseSome()\n throws SAXException, IOException, IllegalAccessException,\n java.lang.reflect.InvocationTargetException\n {\n if(fConfigSetInput!=null)\n {\n Object ret=(Boolean)(fConfigParse.invoke(fPullParserConfig,parmsfalse));\n return ((Boolean)ret).booleanValue();\n }\n else\n {\n Object ret=fParseSome.invoke(fIncrementalParser,noparms);\n return ((Boolean)ret).booleanValue();\n }\n }", "@Override\n\tpublic boolean accept(File pathname) {\n\t\treturn pathname.isHidden();\n\t}", "@Override\n\tpublic boolean canExtract() {\n\t\treturn false;\n\t}", "private Descriptor parseRootDescriptorLine(String line) {\n\t\tString [] tokens = line.split(\"\\\\s+\");\n\t\tif (tokens.length == 5){\n\t\t\tline = tokens[0] + \" \" + tokens[1] + \" \" + tokens[2] + \" \" + tokens[3] + \" 0_0:0_0 0.0\";\n\t\t} else {\n\t\t\tline = line + \" 0_0:0_0 0.0\";\n\t\t}\n\t\treturn this.parseDescriptorLine(line);\n\t}", "private boolean isSerializable(FieldDescriptor childFd, Object object)\n \t\t\tthrows SIMPLTranslationException\n \t{\n \t\tswitch (childFd.getType())\n \t\t{\n \t\tcase SCALAR:\n \t\t\tif (childFd.isDefaultValueFromContext(object))\n \t\t\t\treturn false;\n \t\t\tbreak;\n \t\tcase COMPOSITE_ELEMENT:\n \t\tcase COLLECTION_ELEMENT:\n \t\tcase MAP_ELEMENT:\n \t\t\tObject obj = childFd.getObject(object);\n \t\t\tif (obj == null)\n \t\t\t\treturn false;\n \t\t\tbreak;\n \t\tcase COLLECTION_SCALAR:\n \t\tcase MAP_SCALAR:\n\t\t\tObject scalarCollectionObject = childFd.getObject(object);\n\t\t\tCollection<?> scalarCollection = XMLTools.getCollection(scalarCollectionObject);\n \t\t\tif (scalarCollection == null || scalarCollection.size() <= 0)\n \t\t\t\treturn false;\n \t\t\tbreak;\n \t\t}\n \n \t\treturn true;\n \t}", "public boolean isSetDescription() {\n return this.Description != null;\n }", "boolean isSetDescription();", "boolean isSetDescription();", "public final boolean isEnabled(JsonParser.Feature f)\n/* */ {\n/* 596 */ return (this._parserFeatures & f.getMask()) != 0;\n/* */ }", "boolean hasMetaData();", "public boolean canAbandonFile(OpenDefinitionsDocument doc) { return true; }", "public boolean canAbandonFile(OpenDefinitionsDocument doc) { return true; }", "public boolean isSetDescription() {\n return (this.description != null ? this.description.isSetValue() : false);\n }", "protected void parseDescription(XMPMetadata metadata)\n\t\t\tthrows XmpParsingException, XMLStreamException, XmpSchemaException,\n\t\t\tXmpUnknownValueTypeException, XmpExpectedRdfAboutAttribute,\n\t\t\tBadFieldValueException {\n\t\tnsMap.resetComplexBasicTypesDeclarationInSchemaLevel();\n\t\tint cptNS = reader.get().getNamespaceCount();\n\t\tHashMap<String, String> namespaces = new HashMap<String, String>();\n\t\tfor (int i = 0; i < cptNS; i++) {\n\t\t\tnamespaces.put(reader.get().getNamespacePrefix(i), reader.get()\n\t\t\t\t\t.getNamespaceURI(i));\n\t\t\tif (nsMap.isComplexBasicTypes(reader.get().getNamespaceURI(i))) {\n\t\t\t\t// System.out.println(\"in parseDesc method: prefix:\"+reader.get().getNamespacePrefix(i)+\", nsURI:\"+reader.get().getNamespaceURI(i));\n\t\t\t\tnsMap.setComplexBasicTypesDeclarationForLevelSchema(reader\n\t\t\t\t\t\t.get().getNamespaceURI(i), reader.get()\n\t\t\t\t\t\t.getNamespacePrefix(i));\n\t\t\t}\n\t\t}\n\t\t// Different treatment for PDF/A Extension schema\n\t\t// System.out.println(PDFAExtensionSchema.PDFAEXTENSION+\";\"+PDFAExtensionSchema.PDFAPROPERTY+\";\"+PDFAExtensionSchema.PDFASCHEMA);\n\t\tif (namespaces.containsKey(PDFAExtensionSchema.PDFAEXTENSION)) {\n\t\t\tif (namespaces.containsKey(PDFAExtensionSchema.PDFAPROPERTY)\n\t\t\t\t\t&& namespaces.containsKey(PDFAExtensionSchema.PDFASCHEMA)) {\n\t\t\t\tif (namespaces\n\t\t\t\t\t\t.containsValue(PDFAExtensionSchema.PDFAEXTENSIONURI)\n\t\t\t\t\t\t&& namespaces\n\t\t\t\t\t\t.containsValue(PDFAExtensionSchema.PDFAPROPERTYURI)\n\t\t\t\t\t\t&& namespaces\n\t\t\t\t\t\t.containsValue(PDFAExtensionSchema.PDFASCHEMAURI)) {\n\t\t\t\t\tPDFAExtensionSchema schema = metadata\n\t\t\t\t\t\t\t.createAndAddPDFAExtensionSchemaWithNS(namespaces);\n\t\t\t\t\ttreatDescriptionAttributes(metadata, schema);\n\t\t\t\t\tparseExtensionSchema(schema, metadata);\n\n\t\t\t\t} else {\n\t\t\t\t\tthrow new XmpUnexpectedNamespaceURIException(\n\t\t\t\t\t\t\t\"Unexpected namespaceURI in PDFA Extension Schema encountered\");\n\t\t\t\t}\n\t\t\t} else {\n\t\t\t\tthrow new XmpUnexpectedNamespacePrefixException(\n\t\t\t\t\t\t\"Unexpected namespace Prefix in PDFA Extension Schema\");\n\t\t\t}\n\n\t\t} else {\n\t\t\t// TODO Considering first namespace is that corresponding to the\n\t\t\t// schema (see if it must be changed)\n\t\t\tString namespaceUri = reader.get().getNamespaceURI(0);\n\t\t\tString namespacePrefix = reader.get().getNamespacePrefix(0);\n\t\t\tXMPSchema schema = nsMap.getAssociatedSchemaObject(metadata, namespaceUri, namespacePrefix);\n\t\t\tif (schema != null) {\n\t\t\t\tnamespaces.remove(namespacePrefix);\n\t\t\t} else {\n\t\t\t\tschema = metadata.createAndAddDefaultSchema(namespacePrefix,namespaceUri);\n\t\t\t}\n\t\t\tfor (int i = 1; i < cptNS; i++) {\n\t\t\t\tschema.setAttribute(new Attribute(XMPSchema.NS_NAMESPACE,\n\t\t\t\t\t\t\"xmlns\", reader.get().getNamespacePrefix(i), reader.get().getNamespaceURI(i)));\n\t\t\t}\n\t\t\ttreatDescriptionAttributes(metadata, schema);\n\t\t\twhile (reader.get().nextTag() == XMLStreamReader.START_ELEMENT) {\n\t\t\t\tparseProperty(schema, metadata);\n\t\t\t}\n\t\t}\n\n\t}", "public boolean isSetDescription() {\n return this.description != null;\n }", "public boolean isSetDescription() {\n return this.description != null;\n }", "public boolean isSetDescription() {\n return this.description != null;\n }", "protected boolean isParsing(eIsParsing flag) {\n \t\treturn isParsingStack.size() > 0 && isParsingStack.peek() == flag;\n \t}", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public static boolean declarationType(FileInputStream f){\n if(observer != null){\n observer.parser.setCurrentRule(\"declarationType\", true);\n }\n CToken t = new CToken();\n\n //DataType\n if(!dataType(f)){\n return false;\n }\n if(observer != null){\n observer.parser.setCurrentRule(\"declarationType\", true);\n }\n t = CScanner.getNextToken(f);\n if(observer != null){\n observer.parser.setCurrentToken(t);\n }\n //Identifier\n if (!t.type.equals(\"Identifier\")) {\n System.err.format(\"Syntax Error: In rule DeclarationType unexpected token \\\"%s\\\" of type %s on line %d.\\n\", t.token, t.type, t.lineNum);\n System.exit(0);\n }\n if(observer != null){\n observer.parser.setCurrentRule(\"declarationType\", false);\n }\n return true;\n }", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public boolean hasDefense() {\n return ((bitField0_ & 0x00000800) == 0x00000800);\n }", "public boolean handleOption(Option opt) {\n String optName = opt.getLongOpt();\n \n // Handle --help:\n if ( optName.equals(\"help\") ) {\n printUsage();\n System.exit(0);\n }\n \n // Handle --version\n if ( optName.equals(\"version\") ) {\n System.out.println(\n \"DtdAnalyzer utility, version \" + version + \"\\n\" +\n \"Built \" + buildtime + \"\\n\" +\n \"See http://dtd.nlm.nih.gov/ncbi/dtdanalyzer/\"\n );\n System.exit(0);\n }\n\n // Handle the DTD specifiers\n if (optName.equals(\"doc\") || optName.equals(\"system\") || optName.equals(\"public\")) {\n //System.err.println(\"Found a DTD specifier option, number \" + numDtdsFound);\n if (numDtdsFound + 1 > numDtds) {\n usageError(\"Expected at most \" + numDtds + \" DTD specifier\" +\n (numDtds > 1 ? \"s\" : \"\") + \"!\");\n }\n dtdSpecifiers[numDtdsFound].idType = opt.getId();\n dtdSpecifiers[numDtdsFound].idValue = opt.getValue();\n numDtdsFound++;\n return true;\n }\n \n // Handle the title option(s)\n if (optName.equals(\"title\")) {\n //System.err.println(\"Found title #\" + numTitlesFound + \": '\" + opt.getValue() + \"'\");\n if (numTitlesFound + 1 > numDtds) {\n usageError(\"Too many titles!\");\n }\n dtdSpecifiers[numTitlesFound++].title = opt.getValue();\n return true;\n }\n\n // Handle the --catalog option\n if (optName.equals(\"catalog\")) {\n File catalog = new File(opt.getValue());\n if ( ! catalog.exists() || ! catalog.isFile() ) {\n System.err.println(\"Error: Specified catalog \" + catalog.toString() + \" is not a file\" );\n System.exit(1);\n }\n\n // Set up catalog resolution\n PMCBootStrapper bootstrapper = new PMCBootStrapper();\n CatalogManager catalogManager = new CatalogManager();\n catalogManager.setIgnoreMissingProperties(true);\n URL oasisCatalog = catalogManager.getClass().getResource(App.OASIS_DTD);\n bootstrapper.addMapping(App.OASIS_PUBLIC_ID, oasisCatalog.toString());\n catalogManager.setBootstrapResolver(bootstrapper);\n catalogManager.setCatalogFiles(catalog.toString());\n resolver = new CatalogResolver(catalogManager);\n return true;\n }\n \n // Handle the --roots option. This option should only be used when there's\n // one and only one DTD specified on the command line (i.e. not for dtdcompare).\n if (optName.equals(\"roots\")) {\n roots = opt.getValue().split(\"\\\\s\");\n return true;\n }\n\n // Check for and deal with the comment processor options. \n // These are here under common options, because right now they are required\n // for all commands -- see issue #36. Even after that gets resolved, they\n // will still be needed for both dtdanalyzer and dtddocumentor, so they\n // should stay in the common list.\n if (optName.equals(\"markdown\")) {\n SComment.setCommentProcessor(\"pandoc\");\n return true;\n }\n if (optName.equals(\"docproc\")) {\n SComment.setCommentProcessor(opt.getValue());\n return true;\n }\n if (optName.equals(\"debug\")) {\n debug = true;\n return true;\n }\n\n // Check for and deal with the --param option\n if (optName.equals(\"param\")) {\n String[] values = opt.getValues();\n if (values[0].length() == 0) {\n System.err.println(\"XSLT parameter name can't be empty\");\n System.exit(1);\n }\n xsltParams.addAll(Arrays.asList(values));\n return true;\n }\n\n System.err.println(\"Strange, unhandled command line option. This should never \" +\n \"happen; please create an issue on GitHub.\");\n System.exit(1);\n \n return false;\n }", "public boolean hasCharacteristicDescription() {\n return characteristicDescriptionBuilder_ != null || characteristicDescription_ != null;\n }", "public boolean isSetDescription()\n {\n synchronized (monitor())\n {\n check_orphaned();\n return get_store().count_elements(DESCRIPTION$2) != 0;\n }\n }", "public FileNameComparator(boolean desc) {\n this.desc = desc;\n }", "protected boolean getTableDesc()\n\t\t{\n\t\t\treturn Desc ;\n\t\t}", "public boolean isExtensionListInDescription() {\n\t return useExtensionsInDescription;\n }", "public boolean hasIntrospectionSource() {\n return fieldSetFlags()[16];\n }", "public static File checkDescriptorFileExist(File descriptor) throws IllegalArgumentException {\n if (!descriptor.exists()) {\n throw new IllegalArgumentException(descriptor.getAbsolutePath() + \" does not exist\");\n }\n if (!descriptor.isFile()) {\n throw new IllegalArgumentException(descriptor.getAbsolutePath() + \" is not a file\");\n }\n if (!descriptor.canRead()) {\n throw new IllegalArgumentException(descriptor.getAbsolutePath() + \" is not readable\");\n }\n \n return descriptor;\n }", "private static boolean isDescriptionCommand(String string){\n return stringStartsWith(string, GeneralInfo.PREFIX_COMMAND_DESCRIPTION);\n }", "public boolean hasIntrospectionType() {\n return fieldSetFlags()[17];\n }", "public boolean isPorDescuento();", "public boolean isSetDescription()\n {\n synchronized (monitor())\n {\n check_orphaned();\n return get_store().find_attribute_user(DESCRIPTION$14) != null;\n }\n }", "private boolean peekImplicitSemiColon() {\n return peekImplicitSemiColon(0);\n }", "public boolean isSetDescription()\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return get_store().find_attribute_user(DESCRIPTION$8) != null;\r\n }\r\n }", "public boolean hasParse();", "public boolean isDataFlavorSupported(DataFlavor df) {\n\t\treturn df.equals(CLASS_NODE_FLAVOR);\n\t}", "public boolean isFromAuthoritative()\n {\n if ((this.flag & 0x0400) == 0)\n {\n // not from a authoritative server\n return false;\n }\n\n else return true;\n }", "protected final boolean canReadName( String name )\n throws SAXException\n {\n int i;\n\n for ( i = 0 ; i < name.length() ; ++i ) {\n if ( readChar() != name.charAt( i ) ) {\n pushBack( _curChar );\n while ( i > 0 ) {\n -- i;\n pushBack( name.charAt( i ) );\n }\n return false;\n }\n }\n return true;\n }", "public boolean hasORDERDESCRIPTION() {\n return fieldSetFlags()[1];\n }", "public boolean hasCharacteristicDescription() {\n return characteristicDescription_ != null;\n }", "boolean hasDef();", "public boolean isStructureKnown() {\n return isStructureKnown;\n }" ]
[ "0.6013711", "0.5992219", "0.5959877", "0.56699675", "0.55621046", "0.5447026", "0.5357951", "0.53528893", "0.53281236", "0.53224415", "0.5297106", "0.5275801", "0.50926554", "0.505881", "0.50098604", "0.49668723", "0.4964098", "0.4964098", "0.4964098", "0.49482265", "0.4947489", "0.49100217", "0.4883851", "0.48838103", "0.48561445", "0.48553893", "0.48433292", "0.4840789", "0.48311213", "0.48133194", "0.4799289", "0.47828454", "0.47705305", "0.4764608", "0.47451052", "0.47424543", "0.47336867", "0.4729515", "0.47273055", "0.46942145", "0.46900243", "0.4689803", "0.4657397", "0.46532592", "0.4647375", "0.46383938", "0.46368676", "0.4622947", "0.4621693", "0.4615876", "0.46075603", "0.4586329", "0.45818248", "0.45721588", "0.45638832", "0.45606273", "0.45559615", "0.45557114", "0.45548674", "0.45546186", "0.45546186", "0.4544893", "0.45388934", "0.45348772", "0.45348772", "0.45329458", "0.4529708", "0.45245582", "0.45245582", "0.45245582", "0.45041543", "0.4501813", "0.4501813", "0.4501471", "0.44977456", "0.44942743", "0.44942138", "0.44942138", "0.4490905", "0.44908714", "0.4486627", "0.44862044", "0.44844586", "0.44800103", "0.44724387", "0.44677687", "0.44664532", "0.4464689", "0.44627103", "0.44534096", "0.44532698", "0.4446066", "0.444205", "0.44329357", "0.44319788", "0.4422295", "0.44170955", "0.44153208", "0.44107065", "0.4406929" ]
0.69068366
0
Set whether or not the descriptor alone is parsed
public void setDescriptorOnly( boolean descriptorOnly );
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "boolean isSetDesc();", "public void setDescriptor(Descriptor inDescriptor);", "public boolean isDescriptorOnly();", "boolean isSetDescription();", "boolean isSetDescription();", "boolean isSetInterpretation();", "public void setDirezione(boolean direzione) {\n\r\n }", "public boolean isSetDescription() {\n return (this.description != null ? this.description.isSetValue() : false);\n }", "void set(boolean on);", "private void setSpecifiedImpl (boolean newValue) {\n if (this.specified == newValue)\n return;\n \n Boolean oldValue = this.specified ? Boolean.TRUE : Boolean.FALSE;\n \n this.specified = newValue;\n \n firePropertyChange (PROP_SPECIFIED, oldValue, newValue ? Boolean.TRUE : Boolean.FALSE);\n }", "void setParser(CParser parser);", "IParser setSummaryMode(boolean theSummaryMode);", "private boolean parseSome()\n throws SAXException, IOException, IllegalAccessException,\n java.lang.reflect.InvocationTargetException\n {\n if(fConfigSetInput!=null)\n {\n Object ret=(Boolean)(fConfigParse.invoke(fPullParserConfig,parmsfalse));\n return ((Boolean)ret).booleanValue();\n }\n else\n {\n Object ret=fParseSome.invoke(fIncrementalParser,noparms);\n return ((Boolean)ret).booleanValue();\n }\n }", "public void set(boolean bol);", "protected void setTableDesc(boolean bool)\n\t\t{\n\t\t\tDesc = bool ;\n\t\t}", "@Override\n\t\t\t\tpublic boolean hasParser() {\n\t\t\t\t\treturn true;\n\t\t\t\t}", "public void setParseWithXMP(boolean inValue) {\n if (alreadyParsed && doXMP != inValue) {\n throw new NuxeoException(\n \"Value of 'doXML' cannot be modified after the blob has been already parsed.\");\n }\n doXMP = inValue;\n }", "public void setPredeterminado(boolean predeterminado)\r\n/* 159: */ {\r\n/* 160:274 */ this.predeterminado = predeterminado;\r\n/* 161: */ }", "protected void setParsingFlag(eIsParsing flag) {\n \t\tisParsingStack.push(flag);\n \t}", "public void setElement(boolean value) {\r\n this.element = value;\r\n }", "public boolean isSetDesc()\r\n {\r\n synchronized (monitor())\r\n {\r\n check_orphaned();\r\n return get_store().find_attribute_user(DESC$10) != null;\r\n }\r\n }", "public void setAugment(boolean aValue);", "public void setOn(boolean arg) {\n isOn = arg;\n }", "boolean supports(Object descriptor);", "public void setForua(boolean newValue);", "void set(boolean value);", "public void setHuman(boolean value) {\r\n this.human = value;\r\n }", "public void set()\r\n {\r\n isSet = true;\r\n }", "void setValidSettings(boolean valid);", "IParser setPrettyPrint(boolean thePrettyPrint);", "IParser setOmitResourceId(boolean theOmitResourceId);", "void setString(boolean string);", "public boolean canBuildParser() {\r\n return isParser(getFormatter());\r\n }", "public boolean hasDescription() {\n return fieldSetFlags()[1];\n }", "public void setDescTraslado(Boolean descTraslado){\n this.descTraslado = descTraslado;\n }", "public boolean isSetRFSequenceDesc() {\n return (this.rfSequenceDesc != null ? this.rfSequenceDesc.isSetValue() : false);\n }", "public void setMandatory(String isMandatory) {\n\t\tif (isMandatory != null) {\n\t\t\tif (\"N\".equals(isMandatory) || \"n\".equals(isMandatory)) {\n\t\t\t\tthis.mandatory = false;\n\t\t\t} else if (\"Y\".equals(isMandatory) || \"y\".equals(isMandatory)) {\n\t\t\t\tthis.mandatory = true;\n\t\t\t}\n\t\t}\n\t\t//System.out.println(dataItemName + \" mandatory flag is \" + this.mandatory);\n\t}", "public Builder setDeclarativelyConfigured(boolean value) {\n \n declarativelyConfigured_ = value;\n onChanged();\n return this;\n }", "public void changeIsParalysed()\r\n\t{\r\n\t\tisParalysed = !isParalysed;\r\n\t}", "public void setHarvested(boolean harvested);", "public void setTallied(java.lang.Boolean value);", "public abstract void setInput(boolean value);", "void setChunk(Boolean aIsChunk);", "public void setOldProperty_descriptionType(int param){\n \n // setting primitive attribute tracker to true\n localOldProperty_descriptionTypeTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localOldProperty_descriptionType=param;\n \n\n }", "public void setEnabled(boolean arg){\r\n\t\tenabled = arg;\r\n\t\tif(!arg){\r\n\t\t\tstop(0);\r\n\t\t}\r\n\t\telse{\r\n\t\t\tsonido = new Sonido(path,true);\r\n\t\t}\r\n\t}", "public void setDescargable(boolean descargable) {\n this.descargable = descargable;\n }", "public void setData(boolean isData);", "void setIsManaged(boolean isManaged);", "public void setHasCustom(boolean hasCustom);", "public void setNewProperty_descriptionType(int param){\n \n // setting primitive attribute tracker to true\n localNewProperty_descriptionTypeTracker =\n param != java.lang.Integer.MIN_VALUE;\n \n this.localNewProperty_descriptionType=param;\n \n\n }", "public void setNormalizationState(boolean flag);", "@Override\n\tpublic void setPresent(boolean b) {\n\t\t\n\t}", "public void setModified (boolean modified);", "public boolean isSetDescricao() {\n return this.descricao != null;\n }", "public boolean isSetDescricao() {\n return this.descricao != null;\n }", "public boolean isSetDescricao() {\n return this.descricao != null;\n }", "public boolean isSetDescricao() {\n return this.descricao != null;\n }", "void setBinaryFileAttribute(boolean flag);", "public void setIsModifier(java.lang.Boolean value);", "public void setDescriptor(UtfConstant descriptor)\n {\n m_descriptor = descriptor;\n }", "public boolean isSetDescription() {\n return this.description != null;\n }", "public boolean isSetDescription() {\n return this.description != null;\n }", "public boolean isSetDescription() {\n return this.description != null;\n }", "protected synchronized void setBooleanValue(String tag, boolean flag) {\n if (actualProperties != null) {\n if (flag) {\n actualProperties.put(tag, QVCSConstants.QVCS_YES);\n } else {\n actualProperties.put(tag, QVCSConstants.QVCS_NO);\n }\n }\n }", "private void setChemical(boolean chemical) {\n this.chemical = chemical;\n }", "public void setBool(String parName, boolean parVal) throws HibException;", "public boolean lenientParseEnabled()\n/* */ {\n/* 1271 */ return this.lenientParse;\n/* */ }", "public void setD ( boolean d ) {\n\n\tthis.d = d;\n }", "public void setDescriptor(ClassDescriptor descriptor) {\n this.descriptor = descriptor;\n }", "private void setTagEditable(boolean bool){\n \t\teditTag.setVisible(!bool);\r\n \t\teditTag.setVisible(bool); //actually we want editTag visible false\r\n \t\t\r\n \t\tviewTag.setVisible(bool);\r\n \t\tviewTag.setVisible(!bool); //actually we want viewTag visible true\r\n \t}", "@Override\n\tpublic void setMandatory(boolean mandatory) {\n\t\t\n\t}", "@Override\n public void setAttribute(boolean f)\n {\n checkState();\n attribute = f;\n }", "boolean getDesc();", "boolean isNestimSpecified();", "abstract protected EnumSet<Parser.Flag> getParserFlags();", "public void setMeta (boolean meta) {\n\tthis.meta = meta;\n }", "void setSet(boolean set);", "public boolean isSetDescription() {\n return this.Description != null;\n }", "public boolean isSetTagline() {\n return this.tagline != null;\n }", "public boolean hasDescription() {\n return fieldSetFlags()[4];\n }", "public void setExtended(boolean value) {\n this.extended = value;\n }", "public void setMandatory(boolean mandatory)\n {\n this.mandatory = mandatory;\n performFlags();\n }", "public Parser(boolean debugMe)\n{\n yydebug=debugMe;\n}", "@PropertySetter(role = IS_IMPLICIT)\n\t<E extends CtElement> E setImplicit(boolean b);", "public boolean hasDESCRIPTION() {\n return fieldSetFlags()[1];\n }", "public void setMandatory(boolean value) {\n this.mandatory = value;\n }", "public abstract void setBooleanImpl(String str, boolean z, Resolver<Void> resolver);", "public AdvConditionParser(boolean debugMe)\n{\n yydebug=debugMe;\n}", "boolean setInfo();", "public boolean isSetWithSemanticFiltering() {\r\n return org.apache.thrift.EncodingUtils.testBit(__isset_bitfield, __WITHSEMANTICFILTERING_ISSET_ID);\r\n }", "public void setE ( boolean e ) {\n\n\tthis.e = e;\n }", "protected void DefineFlag()\n {\n String flagStr = \"-ci -d -h -hs -i:STR -n -o:STR -p -s:STR -t:INT -ti -v -x:STR\";\n \n // init the system option\n systemOption_ = new Option(flagStr);\n // Add the full name for flags\n systemOption_.SetFlagFullName(\"-ci\", \"Print_Config_Info\");\n systemOption_.SetFlagFullName(\"-d\", \"Print_Operation_Details\");\n systemOption_.SetFlagFullName(\"-h\", \"Help\");\n systemOption_.SetFlagFullName(\"-hs\", \"Hierarchy_Struture\");\n systemOption_.SetFlagFullName(\"-i\", \"Input_File\");\n systemOption_.SetFlagFullName(\"-n\", \"No_Output\");\n systemOption_.SetFlagFullName(\"-o\", \"Output_File\");\n systemOption_.SetFlagFullName(\"-p\", \"Show_Prompt\");\n systemOption_.SetFlagFullName(\"-s\", \"Field_Separator\");\n systemOption_.SetFlagFullName(\"-t\", \"Term_Field\");\n systemOption_.SetFlagFullName(\"-ti\", \"Display_Filtered_Input\");\n systemOption_.SetFlagFullName(\"-v\", \"Version\");\n systemOption_.SetFlagFullName(\"-x\", \"Load_Configuration_file\");\n }", "@Override\n public void setListening(boolean listening) {\n if (listening) {\n //begin zhixiong.liu.hz for XR 6107743 2018/3/14\n if (!mContext.getResources().getBoolean(R.bool.def_Settings_typecode_enable)) {\n mSummaryLoader.setSummary(this, DeviceModelPreferenceController.getDeviceModel());\n }\n //begin zhixiong.liu.hz for defect 7442064 20190213\n else if(mContext.getResources().getBoolean(R.bool.def_settings_typecode_system_summary_show)){\n mSummaryLoader.setSummary(this,mContext.getResources().getString(R.string.def_Settings_typecode));\n }\n //end zhixiong.liu.hz for defect 7442064 20190213\n //end zhixiong.liu.hz for XR 6107743 2018/3/14\n }\n }", "public void setForm(boolean form);", "public boolean hasParse();", "public void setExternallyManaged(java.lang.Boolean value);", "public void setSilent ( boolean flag ) {\n\t\ttry {\n\t\t\tinvokeSafe ( \"setSilent\" , flag );\n\t\t} catch ( NoSuchMethodError ex ) { // legacy\n\t\t\thandleOptional ( ).ifPresent (\n\t\t\t\t\thandle -> EntityReflection.setSilent ( handle , flag ) );\n\t\t}\n\t}", "protected void setFlag() {\n flag = flagVal;\n }", "protected void setFlag() {\n flag = flagVal;\n }", "public void setRead(){\n \tthis.isRead = true;\n }" ]
[ "0.5963095", "0.5914092", "0.59113026", "0.572992", "0.572992", "0.571069", "0.5694911", "0.56236905", "0.5543963", "0.55107343", "0.5404696", "0.5396891", "0.53886986", "0.538546", "0.5370427", "0.53561294", "0.53540295", "0.5352106", "0.5332122", "0.533143", "0.53124833", "0.53096634", "0.5276232", "0.5269043", "0.5250184", "0.52479315", "0.52372074", "0.5227615", "0.5225527", "0.5212067", "0.52104527", "0.5207876", "0.5203183", "0.5190369", "0.5187103", "0.5186793", "0.51829386", "0.51789254", "0.5178898", "0.5171395", "0.51626956", "0.51608264", "0.5157996", "0.5147649", "0.5142115", "0.513736", "0.5132316", "0.5128702", "0.51131654", "0.5109699", "0.5108766", "0.5107635", "0.51061404", "0.5105944", "0.5105944", "0.5105944", "0.5105944", "0.5100622", "0.50955695", "0.5089334", "0.5083113", "0.5083113", "0.5083113", "0.5077651", "0.50773525", "0.5069308", "0.506834", "0.5054102", "0.50505644", "0.50461644", "0.5041976", "0.5036762", "0.50262487", "0.502338", "0.50191694", "0.5018776", "0.50172555", "0.50126755", "0.50100005", "0.50041944", "0.5000717", "0.49890277", "0.4985988", "0.49857774", "0.4978941", "0.49754572", "0.49688414", "0.49665615", "0.49590144", "0.49516943", "0.4947647", "0.49450514", "0.49405417", "0.49387696", "0.4937722", "0.49348134", "0.49324062", "0.49317527", "0.49317527", "0.4930463" ]
0.64676046
0
Parse the collection according to the provided filter
public void parse( IFilter<? extends IDescribable> filter ) throws ParseException;
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "Results processFilter(FilterSpecifier filter) throws SearchServiceException;", "@Override\n public List runFilter(String filter) {\n return runFilter(\"\", filter);\n }", "public void parse( String ldapFilter )\n {\n // reset state\n filterStack = new Stack<LdapFilter>();\n scanner.reset( ldapFilter );\n model = new LdapFilter();\n\n // handle error tokens before filter\n LdapFilterToken token = scanner.nextToken();\n while ( token.getType() != LdapFilterToken.LPAR && token.getType() != LdapFilterToken.EOF )\n {\n handleError( false, token, model );\n token = scanner.nextToken();\n }\n\n // check filter start\n if ( token.getType() == LdapFilterToken.LPAR )\n {\n // start top level filter\n model.setStartToken( token );\n filterStack.push( model );\n\n // loop till filter end or EOF\n do\n {\n // next token\n token = scanner.nextToken();\n\n switch ( token.getType() )\n {\n case LdapFilterToken.LPAR:\n {\n LdapFilter newFilter = new LdapFilter();\n newFilter.setStartToken( token );\n\n LdapFilter currentFilter = filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n if ( filterComponent != null && filterComponent.addFilter( newFilter ) )\n {\n filterStack.push( newFilter );\n }\n else\n {\n currentFilter.addOtherToken( token );\n }\n\n break;\n }\n case LdapFilterToken.RPAR:\n {\n LdapFilter currentFilter = filterStack.pop();\n handleError( currentFilter.setStopToken( token ), token, currentFilter );\n /*\n * if(!filterStack.isEmpty()) { LdapFilter parentFilter =\n * (LdapFilter) filterStack.peek(); LdapFilterComponent\n * filterComponent = parentFilter.getFilterComponent();\n * filterComponent.addFilter(currentFilter); }\n */\n break;\n }\n case LdapFilterToken.AND:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapAndFilterComponent filterComponent = new LdapAndFilterComponent( currentFilter );\n filterComponent.setStartToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n break;\n }\n case LdapFilterToken.OR:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapOrFilterComponent filterComponent = new LdapOrFilterComponent( currentFilter );\n filterComponent.setStartToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n break;\n }\n case LdapFilterToken.NOT:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapNotFilterComponent filterComponent = new LdapNotFilterComponent( currentFilter );\n filterComponent.setStartToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n break;\n }\n case LdapFilterToken.ATTRIBUTE:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapFilterItemComponent filterComponent = new LdapFilterItemComponent( currentFilter );\n filterComponent.setAttributeToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n break;\n }\n case LdapFilterToken.VALUE:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n if ( filterComponent instanceof LdapFilterItemComponent )\n {\n handleError( ( filterComponent instanceof LdapFilterItemComponent )\n && ( ( LdapFilterItemComponent ) filterComponent ).setValueToken( token ), token,\n currentFilter );\n }\n else if ( filterComponent instanceof LdapFilterExtensibleComponent )\n {\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setValueToken( token ), token,\n currentFilter );\n }\n else\n {\n handleError( false, token, currentFilter );\n }\n break;\n }\n case LdapFilterToken.EQUAL:\n case LdapFilterToken.GREATER:\n case LdapFilterToken.LESS:\n case LdapFilterToken.APROX:\n case LdapFilterToken.PRESENT:\n case LdapFilterToken.SUBSTRING:\n {\n LdapFilter currentFilter = filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n if ( filterComponent instanceof LdapFilterItemComponent )\n {\n handleError( ( filterComponent instanceof LdapFilterItemComponent )\n && ( ( LdapFilterItemComponent ) filterComponent ).setFiltertypeToken( token ), token,\n currentFilter );\n }\n else if ( filterComponent instanceof LdapFilterExtensibleComponent )\n {\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setEqualsToken( token ),\n token, currentFilter );\n }\n else\n {\n handleError( false, token, currentFilter );\n }\n break;\n }\n case LdapFilterToken.WHITESPACE:\n {\n LdapFilter currentFilter = filterStack.peek();\n currentFilter.addOtherToken( token );\n break;\n }\n case LdapFilterToken.EXTENSIBLE_ATTRIBUTE:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterExtensibleComponent filterComponent = new LdapFilterExtensibleComponent(\n currentFilter );\n filterComponent.setAttributeToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n break;\n }\n case LdapFilterToken.EXTENSIBLE_DNATTR_COLON:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n if ( filterComponent == null )\n {\n filterComponent = new LdapFilterExtensibleComponent( currentFilter );\n ( ( LdapFilterExtensibleComponent ) filterComponent ).setDnAttrColonToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n }\n else\n {\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setDnAttrColonToken( token ),\n token, currentFilter );\n }\n break;\n }\n case LdapFilterToken.EXTENSIBLE_DNATTR:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setDnAttrToken( token ), token,\n currentFilter );\n break;\n }\n case LdapFilterToken.EXTENSIBLE_MATCHINGRULEOID_COLON:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n if ( filterComponent == null )\n {\n filterComponent = new LdapFilterExtensibleComponent( currentFilter );\n ( ( LdapFilterExtensibleComponent ) filterComponent ).setMatchingRuleColonToken( token );\n handleError( currentFilter.setFilterComponent( filterComponent ), token, currentFilter );\n }\n else\n {\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent )\n .setMatchingRuleColonToken( token ), token, currentFilter );\n }\n break;\n }\n case LdapFilterToken.EXTENSIBLE_MATCHINGRULEOID:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setMatchingRuleToken( token ),\n token, currentFilter );\n break;\n }\n case LdapFilterToken.EXTENSIBLE_EQUALS_COLON:\n {\n LdapFilter currentFilter = ( LdapFilter ) filterStack.peek();\n LdapFilterComponent filterComponent = currentFilter.getFilterComponent();\n handleError( ( filterComponent instanceof LdapFilterExtensibleComponent )\n && ( ( LdapFilterExtensibleComponent ) filterComponent ).setEqualsColonToken( token ),\n token, currentFilter );\n break;\n }\n\n case LdapFilterToken.EOF:\n {\n model.addOtherToken( token );\n break;\n }\n default:\n {\n LdapFilter currentFilter = filterStack.peek();\n handleError( false, token, currentFilter );\n }\n }\n }\n while ( !filterStack.isEmpty() && token.getType() != LdapFilterToken.EOF );\n }\n\n // handle error token after filter\n token = scanner.nextToken();\n while ( token.getType() != LdapFilterToken.EOF )\n {\n handleError( false, token, model );\n token = scanner.nextToken();\n }\n }", "private void populateFilter() throws TransformerConfigurationException\r\n\t{\r\n\t\tthis.filter = new AddressSet(\"./filtered.xml\");\r\n\t\tthis.filter.addElement(\"postmaster\");\r\n\t\tthis.filter.addElement(\"uucp\");\r\n\t\tthis.filter.addElement(\"mailer-daemon\");\r\n\t\tthis.filter.addElement(\"maildaemon\");\r\n\t\tthis.filter.addElement(\"majordomo\");\r\n\t\tthis.filter.addElement(\"mailerdaemon\");\r\n\t\tthis.filter.addElement(\"abuse@\");\r\n\t\tthis.filter.addElement(\"-relay\");\r\n\t\tthis.filter.addElement(\"-request@\");\r\n\t}", "private void filterClub(String filter) throws JSONException, InterruptedException {\r\n\t /**Database Manager Object used to access mlab.com*/\r\n db.setDataBaseDestination(cDatabase, null, true);\r\n db.accessDatabase();\r\n\r\n MongoCollection<Document> col = db.getEntireDatabaseResults();\r\n \r\n // iterator to go through clubs in database\r\n Iterable<Document> iter;\r\n iter = col.find();\r\n \r\n // ArrayList of clubs matching the filter type \r\n ArrayList<JSONObject> clubs = new ArrayList<>();\r\n \r\n // check clubs to see if they match the type input by the user\r\n for (Document doc : iter) {\r\n JSONObject profile = new JSONObject(doc);\r\n \r\n if (filter.equals(profile.get(\"type\").toString()))\r\n \t clubs.add(profile);\r\n }\r\n \r\n if (clubs.isEmpty()) {\r\n \t logger.log(Level.INFO, \"There are no clubs matching that type.\");\r\n \t displayFilter();\r\n }\r\n else \r\n \t filter(clubs); \r\n}", "List<Receta> getAll(String filter);", "public MapReduceToCollectionOperation filter(final BsonDocument filter) {\n this.filter = filter;\n return this;\n }", "<E extends CtElement> List<E> getElements(Filter<E> filter);", "public Input filterBy(Filter filter) {\n JsonArray filters = definition.getArray(FILTERS);\n if (filters == null) {\n filters = new JsonArray();\n definition.putArray(FILTERS, filters);\n }\n filters.add(Serializer.serialize(filter));\n return this;\n }", "List<Condition> composeFilterConditions(F filter);", "@Override\n\tpublic List<T> getLimitedFilteredResult(Bson filter, int limit) {\n\t\tGson gson = new GsonBuilder().create();\n\t\tList<T> innerList = new ArrayList<>();\n\t\tcollection.find(filter).limit(limit).forEach((Block<Document>) document -> {\n\t\t\tinnerList.add(gson.fromJson(document.toJson(), entityClass));\n\t\t});\n\t\treturn innerList;\n\n\t}", "@Override\n public JsonNode visit(JmesPathFilter filter, JsonNode input) throws InvalidTypeException {\n JsonNode filterExpression = filter.getLhsExpr().accept(this, input);\n if (filterExpression.isArray()) {\n Iterator<JsonNode> elements = filterExpression.elements();\n ArrayNode projectedArrayNode = ObjectMapperSingleton.getObjectMapper().createArrayNode();\n while (elements.hasNext()) {\n JsonNode element = elements.next();\n if (filter.getComparator().accept(this, element).equals(BooleanNode.TRUE)) {\n JsonNode projectedElement = filter.getRhsExpr().accept(this, element);\n if (projectedElement != null) {\n projectedArrayNode.add(projectedElement);\n }\n }\n }\n return projectedArrayNode;\n }\n return NullNode.getInstance();\n }", "public static Filter parse(JsonElement filterElt, Set<String> filterFields) throws FilterParseException {\n String name = Utils.getFieldValueAsString(filterElt, \"name\");\n String opStr = Utils.getFieldValueAsString(filterElt, \"type\");\n if (opStr == null)\n throw new FilterParseException(\"Missing \\\"type\\\" property in\\n \" + filterElt);\n FilterType op = FilterType.parse(opStr);\n FilterPred pred = FilterPred.parse(filterElt, filterFields);\n JsonElement enabledElt = Utils.getFieldValue(filterElt, \"enabled\");\n if (enabledElt != null && enabledElt.isJsonPrimitive()) {\n boolean enabled = enabledElt.getAsBoolean();\n return new Filter(name, op, pred, enabled);\n } else {\n return new Filter(name, op, pred);\n } \n }", "public List setFilter(java.lang.String filter) {\n this.filter = filter;\n return this;\n }", "ArrayList<Match> getMatchList( Filter filter ) {\n return list;\n }", "private static SequentialFilter constructFilterFromSubCommand(String subCommand){\n\t\tsubCommand = subCommand.trim();\n\t\t//Splits the filter into the actual filter command and any parameters it may have\n\t\tString[]command = subCommand.split(\" \", 0);\n\t\t//Saves the first element as the filter command\n\t\tString c = command[0];\n\t\t//saves the rest of the elements as any of the parameters that the filter may have\n\t\t//Only passes the parameters to the filters that require them\n\t\tString [] input = Arrays.copyOfRange(command, 1, command.length);\n\t\tif(c.equals(\"cat\")) {\n\t\t\tCat cat = new Cat(input);\n\t\t\treturn cat;\n\t\t} else if(c.equals(\"pwd\")) {\n\t\t\tPwd pwd = new Pwd();\n\t\t\treturn pwd;\n\t\t} else if(c.equals(\"ls\")) {\n\t\t\tLs ls = new Ls();\n\t\t\treturn ls;\n\t\t} else if(c.equals(\"grep\")) {\n\t\t\tGrep grep = new Grep(input);\n\t\t\treturn grep;\n\t\t}else if(c.equals(\"wc\")) {\n\t\t\tWc wc = new Wc();\n\t\t\treturn wc;\n\t\t} else if(c.equals(\"uniq\")) {\n\t\t\tUniq uniq = new Uniq();\n\t\t\treturn uniq;\n\t\t} else if(c.equals(\">\")) {\n\t\t\tRedirect redirect = new Redirect(input);\n\t\t\treturn redirect;\n\t\t} else if(c.equals(\"output\")){\n\t\t\tOutput output = new Output();\n\t\t\treturn output;\n\t\t} else {\n\t\t\tString s = Arrays.deepToString(input);\n\t\t\ts = s.replace(\"[\", \"\");\n\t\t\ts = s.replace(\"]\", \"\");\n\t\t\ts = s.replace(\",\", \"\");\n\t\t\tthrow new RuntimeException(Message.COMMAND_NOT_FOUND.with_parameter(c + \" \" + s));\n\t\t}\n\t}", "public<T> List<T> takeWhile(final Collection<T> collection, final Filter<T> filter ){\t\t\n\t\tList<T> result = create.createLinkedList();\n\t\tfor(T t:query.getOrEmpty(collection)){\t\t\t\n\t\t\tif(!filter.applicable(t)){\n\t\t\t\treturn result;\n\t\t\t}\n\t\t\tresult.add(t);\n\t\t}\n\t\treturn result;\n\t}", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n constraint = constraint.toString().toLowerCase();\n FilterResults result = new FilterResults();\n if (constraint != null && constraint.toString().length() > 0) {\n List<Message> filt = new ArrayList<Message>(); //filtered list\n for (int i = 0; i < originalData.size(); i++) {\n Message m = originalData.get(i);\n if (m.getSender().getEmailAddress().getName().toLowerCase().contains(constraint)) {\n filt.add(m); //add only items which matches\n }\n }\n result.count = filt.size();\n result.values = filt;\n } else { // return original list\n synchronized (this) {\n result.values = originalData;\n result.count = originalData.size();\n }\n }\n return result;\n }", "private Reviews filterByFunc(FilterFunction filterFunc)\n\t{\n\t\tArrayList<Review> filteredList = new ArrayList<Review>();\n\t\tfor(Review review : list)\n\t\t\tif(filterFunc.filter(review))\n\t\t\t\tfilteredList.add(review);\n\t\treturn new Reviews(filteredList);\n\t}", "Collection<T> doFilter(RepositoryFilterContext context);", "void setFilter(String filter);", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n\n FilterResults results=new FilterResults();\n\n if(constraint != null && constraint.length()>0)\n {\n //CONSTARINT TO UPPER\n constraint=constraint.toString().toUpperCase();\n\n ArrayList<Busqueda> filters=new ArrayList<Busqueda>();\n\n //get specific items\n for(int i=0;i<FilterDatos.size();i++)\n {\n if(FilterDatos.get(i).getTitulo().toUpperCase().contains(constraint))\n {\n Busqueda p=new Busqueda();\n p.setId(FilterDatos.get(i).getId());\n p.setTitulo(FilterDatos.get(i).getTitulo());\n p.setDescripcion(FilterDatos.get(i).getDescripcion());\n p.setContraseña(FilterDatos.get(i).getContraseña());\n p.setLongitud(FilterDatos.get(i).getLongitud());\n p.setTerminada(FilterDatos.get(i).getTerminada());\n p.setPuntos(FilterDatos.get(i).getPuntos());\n filters.add(p);\n }\n }\n\n results.count=filters.size();\n results.values=filters;\n\n }else\n {\n results.count=FilterDatos.size();\n results.values=FilterDatos;\n\n }\n\n return results;\n }", "public void setFilter(String filter) {\n\t\tthis.filter = filter;\n\n\t}", "List<FormSubmit> selectListByFilter( ResponseFilter filter, Plugin plugin );", "public void addBusinessFilterToCreator(ViewerFilter filter);", "@Override\n public Filter getFilter() {\n\n return new Filter() {\n @Override\n protected FilterResults performFiltering(CharSequence charSequence) {\n\n String charString = charSequence.toString();\n\n if (charString.isEmpty()) {\n\n mDataset = mArrayList;\n } else {\n\n ArrayList<DataObject> filteredList = new ArrayList<>();\n\n for (DataObject data : mArrayList) {\n\n if (data.getid().toLowerCase().contains(charString.toLowerCase()) || data.getname().toLowerCase().contains(charString.toLowerCase())) {\n\n filteredList.add(data);\n }\n }\n\n mDataset = filteredList;\n }\n\n FilterResults filterResults = new FilterResults();\n filterResults.values = mDataset;\n return filterResults;\n }\n\n @Override\n protected void publishResults(CharSequence charSequence, FilterResults filterResults) {\n mDataset = (ArrayList<DataObject>) filterResults.values;\n notifyDataSetChanged();\n }\n };\n }", "public LdapFilterParser()\n {\n this.scanner = new LdapFilterScanner();\n this.model = new LdapFilter();\n }", "public abstract List<Course> getByFilter(HashMap<String, String> filter);", "public void addBusinessFilterToReader(ViewerFilter filter);", "<T> Collection<T> parseToCollectionObjects(Object json, Type typeClass);", "public LinkedList<Article> filterArticleList(int filter)\n\t{\n\t\treturn null;\n\t}", "public List<StudentRecord> filter(IFilter filter) {\n\t\tList<StudentRecord> temporaryList = new ArrayList<>();\n\n\t\tfor (StudentRecord studentRecord : studentRecords) {\n\t\t\tif (filter.accepts(studentRecord)) {\n\t\t\t\ttemporaryList.add(studentRecord);\n\t\t\t}\n\t\t}\n\t\treturn temporaryList;\n\t}", "public String process() {\r\n if (typeNames == null) return filterString;\r\n\r\n String filterStringProcessed = filterString;\r\n\r\n for (QName typeName : typeNames) {\r\n String typeNameValue = typeName.getValue();\r\n\r\n String[] tokens = typeNameValue.split(\"_\");\r\n\r\n if (tokens.length > 1) {\r\n String type = tokens[0];\r\n String[] names = new String[tokens.length-1];\r\n System.arraycopy(tokens,1, names, 0, tokens.length-1);\r\n \r\n for (int i = 0; i < names.length; i++) {\r\n filterStringProcessed = replaceNamesWithType(filterStringProcessed, names[i], type);\r\n }\r\n }\r\n }\r\n\r\n return filterStringProcessed;\r\n }", "java.lang.String getFilter();", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n\n List<CasesItem> filteredList = new ArrayList<>();\n if(constraint == null || constraint.length() == 0) {\n\n filteredList.addAll(mItemCasesAll);\n } else {\n\n String filterPattern = constraint.toString().toLowerCase().trim();\n for(CasesItem items: mItemCasesAll) {\n\n if(items.getmCountryName().toLowerCase().contains(filterPattern)) {\n\n filteredList.add(items);\n }\n }\n }\n\n FilterResults filterResults = new FilterResults();\n filterResults.values = filteredList;\n return filterResults;\n }", "public ContentList filterContentList(ContentDatabaseFilter filter) throws DatabaseException;", "@Override\n protected FilterResults performFiltering(CharSequence arg0) {\n FilterResults filterResults = new FilterResults();\n if (arg0 == null || arg0.length() == 0) {\n filterResults.values = MyArrayObjects;\n filterResults.count = MyArrayObjects.size();\n } else {\n String filterString = arg0.toString().toLowerCase();\n final ArrayList<Com_ItemObject> TempList = new ArrayList<Com_ItemObject>();\n for (Com_ItemObject Sis_ItemObject : MyArrayObjects) {\n //Filters both from Name and Bottom Text\n if ((Sis_ItemObject.getName() + \" \" + Sis_ItemObject.getBottomText()).toLowerCase().contains(filterString)) {\n TempList.add(Sis_ItemObject);\n }\n }\n\n filterResults.values = TempList;\n filterResults.count = TempList.size();\n }\n\n return filterResults;\n }", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n List<EventDTO> filteredList = new ArrayList<>();\n /* If the given charSequence (Users input in searchview) is 0 or null, if so readies all events to be searched through */\n if(constraint == null || constraint.length() == 0) {\n filteredList.addAll(itemsToAdaptComplete);\n } else {\n /* Makes input not case sensitive */\n String filterPattern = constraint.toString().toLowerCase().trim(); // Locale.ROOT\n /* Searches through all of the events to check for matching characters */\n for (EventDTO item : itemsToAdaptComplete) {\n if (item.getName().toLowerCase().contains(filterPattern)) {\n filteredList.add(item);\n }\n }\n }\n /* Sets results */\n FilterResults results = new FilterResults();\n results.values = filteredList;\n return results;\n }", "protected List<Object> getPreFilters(List<Object> list, Class<T> entityClass, Pageable filter)\r\n {\r\n if (preFilterAccessor != null) {\r\n list.addAll(preFilterAccessor.getPreFilters(entityClass, filter));\r\n }\r\n return list;\r\n }", "Get<K, C> addFilter(Filter<K, C> filter);", "public List<PedidoIndividual> filtrar(PedidoIndividual filtro);", "private void updateFilter(BasicOutputCollector collector) {\n if (updateFilter()){\n \tValues v = new Values();\n v.add(ImmutableList.copyOf(filter));\n \n collector.emit(\"filter\",v);\n \t\n }\n \n \n \n }", "public Builder filter(String filter) {\n request.filter = filter;\n return this;\n }", "@Override\n\tpublic List<Visit> load(int first, int pageSize, String sortField, SortOrder sortOrder, \n\t\t\tMap<String, Object> filters) {\n\n\t\t\n\t\treturn result;\n\t}", "@Override\n protected void publishResults(CharSequence arg0, FilterResults arg1) {\n FilteredObjects = (ArrayList<Com_ItemObject>) arg1.values;\n notifyDataSetChanged();\n }", "public RTTIClass select(ClassFilter filter);", "public List<PlantDTO> fetchPlants(String filter);", "public void addFilterToCreator(ViewerFilter filter);", "public FilterResults performFiltering(CharSequence constraint) {\n FilterResults results = new FilterResults();\n if (constraint == null || constraint.length() == 0) {\n results.values = CaSiAdapter.this.listSort;\n results.count = CaSiAdapter.this.listSort.size();\n } else {\n ArrayList<CaSi> lsSach = new ArrayList<>();\n Iterator it = CaSiAdapter.this.list.iterator();\n while (it.hasNext()) {\n CaSi p = (CaSi) it.next();\n if (String.valueOf(p.getMaCS()).toUpperCase().contains(constraint.toString().toUpperCase()) || p.getHoTenCS().toUpperCase().contains(constraint.toString().toUpperCase())) {\n lsSach.add(p);\n }\n }\n results.values = lsSach;\n results.count = lsSach.size();\n }\n return results;\n }", "Filter getFilter();", "public abstract void filter();", "public void parseGraph(IGraph graph, TreeItem<Object> root, String filter) {\n\n\n TreeItem<Object> graphItem = new TreeItem<>(graph\n // .getID()\n );\n\n root.getChildren().add(graphItem);\n if (this.showNodes) {\n TreeItem<Object> nodeTI = new TreeItem<>(graph + \" Nodes (\"\n + graph.getNodes().size() + \")\");\n graphItem.getChildren().add(nodeTI);\n\n for (INode node : graph.getNodes()) {\n\n if (node.getID().contains(filter)) {\n\n this.parseNode(node, nodeTI, filter);\n }\n }\n }\n\n if (this.showEdges) {\n\n TreeItem<Object> edgeTI = new TreeItem<>(graph + \" Edges (\"\n + graph.getEdges().size() + \")\");\n graphItem.getChildren().add(edgeTI);\n\n for (IEdge edge : graph.getEdges()) {\n\n if (edge.toString().contains(filter)) {\n\n this.parseEdge(edge, edgeTI, filter);\n }\n }\n }\n if (this.showHyperEdges) {\n TreeItem<Object> hyperTI = new TreeItem<>(graph\n + \"Hyperedges (\" + graph.getHyperEdges().size() + \")\");\n graphItem.getChildren().add(hyperTI);\n for (IHyperEdge he : graph.getHyperEdges()) {\n\n if (he.getID().contains(filter)) {\n\n this.parseHyperEdge(he, hyperTI, filter);\n }\n }\n }\n }", "@POST\n\t@Path(\"/findbyfilter\")\n\t@Consumes({ MediaType.APPLICATION_JSON })\n\t@Produces({ MediaType.APPLICATION_JSON })\n\tpublic Response findByfilter(final AreaTO filterTO) {\n\n\t\tGenericEntity<List<AreaTO>> entity = null;\n\n\t\ttry {\n\n\t\t\tfinal Area filter = new Area();\n\t\t\tPropertyUtils.copyProperties(filter, filterTO);\n\n\t\t\tfinal Users user = this.usersService.findByCDSID(this.requestContext.getUserId());\n\t\t\tfilter.setCountryC(FunctionsUtils.validateInteger(user.getCountryDbC()));\n\n\t\t\tfinal List<AreaTO> listAreaTO = new ArrayList<AreaTO>();\n\t\t\tfinal List<Area> listArea = this.areaService.findByFilter(filter);\n\n\t\t\tif (listArea != null && listArea.size() > 0) {\n\n\t\t\t\tfor (final Area area : listArea) {\n\t\t\t\t\tfinal AreaTO areaTO = new AreaTO();\n\t\t\t\t\tPropertyUtils.copyProperties(areaTO, area);\n\t\t\t\t\tlistAreaTO.add(areaTO);\n\t\t\t\t}\n\n\t\t\t\tentity = new GenericEntity<List<AreaTO>>(listAreaTO) {\n\t\t\t\t\t// teste...\n\t\t\t\t};\n\t\t\t}\n\n\t\t} catch (final ApplicationException e) {\n\n\t\t\tfinal ErrorTO erro = new ErrorTO();\n\t\t\terro.setCodigoIncident(e.getLogReferenceCode());\n\n\t\t\tfinal ResourceBundle bundle = ResourceBundle.getBundle(\"ApplicationResources\");\n\n\t\t\tfinal List<ErrorType> erros = e.getErrorTypes();\n\n\t\t\tfor (final ErrorType errorType : erros) {\n\t\t\t\terro.setMessage(bundle.getString(errorType.getKey()));\n\t\t\t}\n\n\t\t\treturn this.buildResponse(erro, Status.INTERNAL_SERVER_ERROR);\n\n\t\t} catch (final Exception ex) {\n\n\t\t\tfinal ErrorTO erro = new ErrorTO();\n\t\t\terro.setMessage(\"Fatal Error\");\n\n\t\t\treturn this.buildResponse(erro, Status.INTERNAL_SERVER_ERROR);\n\t\t}\n\n\t\treturn buildResponseListOK(entity);\n\n\t}", "public void filterEdges(String filter) {\n\n\n tree_graphs.getChildren().clear();\n populate(universe, filter, this.showNodes, this.showEdges,\n this.showHyperEdges);\n\n\n tree_edges.getChildren().clear();\n for (IEdge edge : universe.getEdges()) {\n if (edge.toString().contains(filter)) {\n parseEdge(edge, tree_edges, filter);\n }\n }\n\n }", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n\n FilterResults results = new FilterResults();\n if (constraint != null && constraint.length() > 0) {\n\n ArrayList<VehicleData> filterList = new ArrayList<>();\n\n for (int i = 0; i < mflatFilterList.size(); i++) {\n if (\n mflatFilterList.get(i).getName().toLowerCase().contains(constraint.toString().toLowerCase())\n || mflatFilterList.get(i).getNumber().toLowerCase().contains(constraint.toString().toLowerCase())\n || mflatFilterList.get(i).getModel().toLowerCase().contains(constraint.toString().toLowerCase())\n || mflatFilterList.get(i).getColor().toLowerCase().contains(constraint.toString().toLowerCase())\n || mflatFilterList.get(i).getFlat().getNumber().toLowerCase().contains(constraint.toString().toLowerCase())\n || mflatFilterList.get(i).getFlat().getName().toLowerCase().contains(constraint.toString().toLowerCase())\n ) {\n filterList.add(mflatFilterList.get(i));\n }\n }\n\n results.count = filterList.size();\n\n results.values = filterList;\n\n } else {\n results.count = mflatFilterList.size();\n results.values = mflatFilterList;\n }\n return results;\n }", "private static Filter newFilter()\r\n {\r\n Filter filter = new Filter(\"filter1\", new Source(\"display1\", \"name1\", \"server\", \"key1\"));\r\n filter.getOtherSources().add(filter.getSource());\r\n Group group = new Group();\r\n group.addFilterCriteria(new Criteria(\"field1\", Conditional.EQ, \"123\"));\r\n Group group2 = new Group();\r\n group2.addFilterCriteria(new Criteria(\"field1\", Conditional.EQ, \"124\"));\r\n group.addFilterGroup(group2);\r\n filter.setFilterGroup(group);\r\n return filter;\r\n }", "public void filterNodes(String filter) {\n\n\n tree_graphs.getChildren().clear();\n populate(universe, filter, this.showNodes, this.showEdges,\n this.showHyperEdges);\n\n\n tree_nodes.getChildren().clear();\n for (INode node : universe.getNodes()) {\n if (node.getID().contains(filter)) {\n parseNode(node, tree_nodes, filter);\n }\n }\n\n }", "private void initFilter() {\r\n if (filter == null) {\r\n filter = new VocabularyConceptFilter();\r\n }\r\n filter.setVocabularyFolderId(vocabularyFolder.getId());\r\n filter.setPageNumber(page);\r\n filter.setNumericIdentifierSorting(vocabularyFolder.isNumericConceptIdentifiers());\r\n }", "private void setUpFilter() {\n List<Department> departmentsList = departmentService.getAll(0, 10000);\n departments.setItems(departmentsList);\n departments.setItemLabelGenerator(Department::getDepartment_name);\n departments.setValue(departmentsList.get(0));\n category.setItems(\"Consumable\", \"Asset\", \"%\");\n category.setValue(\"%\");\n status.setItems(\"FREE\", \"IN USE\", \"%\");\n status.setValue(\"%\");\n show.addClickListener(click -> updateGrid());\n }", "public ArrayList<CampusEvent> eventListFilter (ArrayList<CampusEvent> campusEvents, Filters filter) {\n ArrayList<CampusEvent> newList = new ArrayList<CampusEvent>();\n //if all the filters are zero, return original list\n Log.d(Globals.TAGG, \"Showing what the filters are\");\n\n if (filter == null) {\n Log.d(Globals.TAGG, \"All filters are null\");\n return campusEvents;\n } else {\n if (filter.getfFood() == 0 && filter.getfEventType() == 0 && filter.getfProgramType() == 0 && filter.getfGender() == 0 && filter.getfGreekSociety() == 0 && filter.getfMajor() == 0 && filter.getfYear() == 0) {\n return campusEvents;\n }\n if (filter.getfFood() != 0) {\n for (CampusEvent event : campusEvents) {\n int scaleval = filter.getfFood() - 1;\n if (event.getFood() == scaleval) {\n newList.add(event);\n }\n }\n }\n if (filter.getfEventType() != 0) {\n for (CampusEvent event : campusEvents) {\n int scaleval = filter.getfEventType() - 1;\n if (event.getEventType() == scaleval) {\n newList.add(event);\n }\n }\n }\n\n if (filter.getfProgramType() != 0) {\n for (CampusEvent event : campusEvents) {\n if (event.getProgramType() == filter.getfProgramType()) {\n newList.add(event);\n }\n }\n }\n\n if (filter.getfYear() != 0) {\n for (CampusEvent event : campusEvents) {\n if (event.getYear() == filter.getfYear()) {\n newList.add(event);\n }\n }\n }\n\n if (filter.getfMajor() != 0) {\n for (CampusEvent event : campusEvents) {\n if (event.getMajor() == filter.getfMajor()) {\n newList.add(event);\n }\n }\n }\n\n if (filter.getfGender() != 0) {\n for (CampusEvent event : campusEvents) {\n if (event.getGender() == filter.getfGender()) {\n newList.add(event);\n }\n }\n }\n\n if (filter.getfGreekSociety() != 0) {\n for (CampusEvent event : campusEvents) {\n if (event.getGreekSociety() == filter.getfGreekSociety()) {\n newList.add(event);\n }\n }\n }\n\n return newList;\n }\n }", "public FilterResults performFiltering(CharSequence constraint) {\n FilterResults results = new FilterResults();\n if (constraint == null || constraint.length() == 0) {\n results.values = BaiHatAdapter.this.listSort;\n results.count = BaiHatAdapter.this.listSort.size();\n } else {\n ArrayList<BaiHat> lsSach = new ArrayList<>();\n Iterator it = BaiHatAdapter.this.list.iterator();\n while (it.hasNext()) {\n BaiHat p = (BaiHat) it.next();\n if (String.valueOf(p.getMaBH()).toUpperCase().startsWith(constraint.toString().toUpperCase()) ||\n String.valueOf(p.getTenBH()).toUpperCase().startsWith(constraint.toString().toUpperCase()) ||\n String.valueOf(p.getNamSangTac()).toUpperCase().startsWith(constraint.toString().toUpperCase())) {\n lsSach.add(p);\n }\n }\n results.values = lsSach;\n results.count = lsSach.size();\n }\n return results;\n }", "public Results(FilterSpecifier filter) {\r\n this.ctypes = new ArrayList<ColumnType>();\r\n if (filter.getColumnTypes() != null) {\r\n for (ColumnType ctype : filter.getColumnTypes()) {\r\n if (ctype.isPicked()) {\r\n ctypes.add(ctype);\r\n }\r\n }\r\n }\r\n this.listBy = filter.getListBy();\r\n this.geneList = filter.getGeneList();\r\n this.patientList = filter.getPatientList();\r\n this.disease = filter.getDisease();\r\n this.chromRegions = filter.getChromRegions();\r\n this.geneListOptions = filter.getGeneListOptions();\r\n this.patientListOptions = filter.getPatientListOptions();\r\n }", "java.lang.String getDataItemFilter();", "public List<Integer> selectIdListByFilter( SubmitFilter filter, Plugin plugin )\n {\n List<Integer> suggestSubmitIdList = new ArrayList<Integer>( );\n List<String> listStrFilter = new ArrayList<String>( );\n String strOrderBy = null;\n\n if ( filter.containsIdSuggest( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST );\n }\n\n if ( filter.containsIdSuggestSubmit( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST_SUBMIT );\n }\n\n if ( filter.containsIdSuggestSubmitState( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST_SUBMIT_STATE );\n }\n\n if ( filter.containsIdCategory( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_CATEGORY );\n }\n\n if ( filter.containsDateFirst( ) )\n {\n listStrFilter.add( SQL_FILTER_DATE_FIRST_SUBMIT );\n }\n\n if ( filter.containsDateLast( ) )\n {\n listStrFilter.add( SQL_FILTER_DATE_LAST_SUBMIT );\n }\n\n if ( filter.containsIdReported( ) )\n {\n listStrFilter.add( SQL_FILTER_REPORTED );\n }\n\n if ( filter.containsNumberVote( ) )\n {\n listStrFilter.add( SQL_FILTER_NUMBER_VOTE );\n }\n\n if ( filter.containsIdPinned( ) )\n {\n listStrFilter.add( SQL_FILTER_IS_PINNED );\n }\n if ( filter.containsLuteceUserKey())\n {\n listStrFilter.add( SQL_FILTER_LUTECE_USER_KEY);\n }\n\n if ( filter.containsIdType( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_TYPE );\n }\n \n \n \n\n if ( filter.containsIdContainsCommentDisable( ) )\n {\n listStrFilter.add( ( filter.getIdContainsCommentDisable( ) == SubmitFilter.ID_TRUE )\n ? SQL_FILTER_CONTAINS_COMMENT_DISABLE : SQL_FILTER_NOT_CONTAINS_COMMENT_DISABLE );\n }\n\n if ( filter.containsSortBy( ) )\n {\n strOrderBy = getOrderBy( filter.getSortBy( ) );\n }\n\n //\t\tif(filter.isOrderByScore())\n //\t\t{\n //\t\t\tstrSQL += SQL_ORDER_BY_SCORE;\n //\t\t}\n //\t\telse if(filter.isOrderByCommentNumber())\n //\t\t{\n //\t\t\tstrSQL += SQL_ORDER_BY_COMMENT_NUMBER_ASC;\n //\t\t}\n //\t\telse\n //\t\t{\n //\t\t\tstrSQL += SQL_ORDER_BY_DATE_RESPONSE;\n //\t\t}\n String strSQL = SuggestUtils.buildRequestWithFilter( SQL_QUERY_SELECT_ID_SUGGEST_SUBMIT_BY_FILTER, listStrFilter,\n strOrderBy );\n DAOUtil daoUtil = new DAOUtil( strSQL, plugin );\n int nIndex = 1;\n\n if ( filter.containsIdSuggest( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggest( ) );\n nIndex++;\n }\n\n if ( filter.containsIdSuggestSubmit( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggestSubmit( ) );\n nIndex++;\n }\n\n if ( filter.containsIdSuggestSubmitState( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggestSubmitState( ) );\n nIndex++;\n }\n\n if ( filter.containsIdCategory( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdCategory( ) );\n nIndex++;\n }\n\n if ( filter.containsDateFirst( ) )\n {\n daoUtil.setTimestamp( nIndex, filter.getDateFirst( ) );\n nIndex++;\n }\n\n if ( filter.containsDateLast( ) )\n {\n daoUtil.setTimestamp( nIndex, filter.getDateLast( ) );\n nIndex++;\n }\n\n if ( filter.containsIdReported( ) )\n {\n daoUtil.setBoolean( nIndex, filter.convertIdBoolean( filter.getIdReported( ) ) );\n nIndex++;\n }\n\n if ( filter.containsNumberVote( ) )\n {\n daoUtil.setInt( nIndex, filter.getNumberVote( ) );\n nIndex++;\n }\n\n if ( filter.containsIdPinned( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdPinned( ) );\n nIndex++;\n }\n \n if ( filter.containsLuteceUserKey())\n {\n \t daoUtil.setString( nIndex, filter.getLuteceUserKey());\n \t nIndex++;\n }\n\n if ( filter.containsIdType( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdType( ) );\n nIndex++;\n }\n \n\n daoUtil.executeQuery( );\n\n while ( daoUtil.next( ) )\n {\n suggestSubmitIdList.add( daoUtil.getInt( 1 ) );\n }\n\n daoUtil.free( );\n\n return suggestSubmitIdList;\n }", "private void updateFilteredData() {\n mainApp.getFilteredData().clear();\n\n for (FilmItem p : mainApp.getFilmData()) {\n if (matchesFilter(p)) {\n \tmainApp.getFilteredData().add(p);\n }\n }\n }", "@Override\n public void filter(String type) {\n\n List<Doctor> newDocs = new ArrayList<>();\n \n for (Doctor doctor : doctors) {\n //If doctor's specialization matches user searched specialization add to new doctor list\n if (doctor.getSpecialization()!=null && doctor.getSpecialization().equals(type)) {\n newDocs.add(doctor);\n }\n }\n \n //Set new doctor list as the doctor list\n doctors = newDocs;\n }", "private void filterData(String tit, String loc, String datef, String datet, String cat, String cou){\n String t = tit;\n String l = loc;\n String df = datef;\n String dt = datet;\n String c = cat;\n String country = cou;\n filteredData.clear();\n\n SimpleDateFormat dateFormat = new SimpleDateFormat(\"dd-MM-yyyy\", Locale.US);\n\n //All empty\n if(t.length() == 0 && country.length() == 0 && c.length() == 0){\n for(int i = 0; i < data.size(); i++){\n filteredData.add(data.get(i));\n }\n }\n\n //only title\n if(t.length() != 0 && country.length() == 0 && c.length() == 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getTitle().equals(t)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //only country\n if(t.length() == 0 && country.length() != 0 && c.length() == 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getCountry().equals(country)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //only category\n if(t.length() == 0 && country.length() == 0 && c.length() != 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getCategory().equals(c)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //only date\n if(t.length() == 0 && country.length() == 0 && c.length() == 0 && df.length() != 0 && dt.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title and country\n if(t.length() != 0 && country.length() != 0 && c.length() == 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getTitle().equals(t) && data.get(i).getCountry().equals(country)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title and category\n if(t.length() != 0 && country.length() == 0 && c.length() != 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getCategory().equals(c) && data.get(i).getTitle().equals(t)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title, date\n if(t.length() != 0 && country.length() == 0 && c.length() == 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getTitle().equals(t) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //country, category\n if(t.length() == 0 && country.length() != 0 && c.length() != 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getCategory().equals(c) && data.get(i).getCountry().equals(country)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //country, date\n if(t.length() == 0 && country.length() != 0 && c.length() == 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getCountry().equals(country) && data.get(i).getTitle().equals(t) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //category, date\n if(t.length() == 0 && country.length() == 0 && c.length() != 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getCategory().equals(c) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title, country, category\n if(t.length() != 0 && country.length() != 0 && c.length() != 0 && df.length() == 0){\n for(int i = 0; i < data.size(); i++){\n if(data.get(i).getTitle().equals(t) && data.get(i).getCountry().equals(country) && data.get(i).getCategory().equals(c)){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title, country, date\n if(t.length() != 0 && country.length() != 0 && c.length() == 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getTitle().equals(t) && data.get(i).getCountry().equals(country) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title, category, date\n if(t.length() != 0 && country.length() == 0 && c.length() != 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getTitle().equals(t) && data.get(i).getCategory().equals(c) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n\n //country, category, date\n if(t.length() == 0 && country.length() != 0 && c.length() != 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getCategory().equals(c) && data.get(i).getCountry().equals(country) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n\n //title, country, category and date\n if(t.length() != 0 && country.length() != 0 && c.length() != 0 && df.length() != 0){\n for(int i = 0; i < data.size(); i++){\n String dateeee = data.get(i).getDate();\n try {\n datefrom = dateFormat.parse(df);\n dateto = dateFormat.parse(dt);\n datadate = dateFormat.parse(dateeee);\n } catch (ParseException e) {\n e.printStackTrace();\n }\n if(data.get(i).getTitle().equals(t) && data.get(i).getCategory().equals(c) && data.get(i).getCountry().equals(country) && datadate.compareTo(datefrom) >= 0 && datadate.compareTo(dateto) <= 0){\n filteredData.add(data.get(i));\n }\n }\n }\n }", "private void isFiltersSatisfied() {\n Filter[] filters = rule.getFilters();\n for (int i = 0; i < filters.length; i++) {\n linkedList.add(filters[i]);\n }\n recursiveFiltering(linkedList.peek().filter.split(\":\"),null);\n }", "List<ParseData> parse(ParseDataSettings parseData);", "public void addBusinessFilterToAnotations(ViewerFilter filter);", "public void addBusinessFilterToAnotations(ViewerFilter filter);", "public Object visit(ProcessInstanceFilter filter, Object context)\n {\n if (filter.isIncludingSubprocesses())\n {\n return new Node(new HashSet(filter.getOids()), null);\n }\n else\n {\n return new Node(null, new HashSet(filter.getOids()));\n }\n }", "public List<SuggestSubmit> selectListByFilter( SubmitFilter filter, Plugin plugin )\n {\n List<SuggestSubmit> suggestSubmitList = new ArrayList<SuggestSubmit>( );\n\n List<String> listStrFilter = new ArrayList<String>( );\n String strOrderBy = null;\n\n listStrFilter.add( SQL_JOIN_STATE );\n\n if ( filter.containsIdSuggestSubmit( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST_SUBMIT );\n }\n\n if ( filter.containsIdSuggest( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST );\n }\n\n if ( filter.containsIdSuggestSubmitState( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_SUGGEST_SUBMIT_STATE );\n }\n\n if ( filter.containsIdCategory( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_CATEGORY );\n }\n\n if ( filter.containsDateFirst( ) )\n {\n listStrFilter.add( SQL_FILTER_DATE_FIRST_SUBMIT );\n }\n\n if ( filter.containsDateLast( ) )\n {\n listStrFilter.add( SQL_FILTER_DATE_LAST_SUBMIT );\n }\n\n if ( filter.containsIdReported( ) )\n {\n listStrFilter.add( SQL_FILTER_REPORTED );\n }\n\n if ( filter.containsNumberVote( ) )\n {\n listStrFilter.add( SQL_FILTER_NUMBER_VOTE );\n }\n\n if ( filter.containsIdPinned( ) )\n {\n listStrFilter.add( SQL_FILTER_IS_PINNED );\n }\n\n if ( filter.containsIdType( ) )\n {\n listStrFilter.add( SQL_FILTER_ID_TYPE );\n }\n\n if ( filter.containsIdContainsCommentDisable( ) )\n {\n listStrFilter.add( ( filter.getIdContainsCommentDisable( ) == SubmitFilter.ID_TRUE )\n ? SQL_FILTER_CONTAINS_COMMENT_DISABLE : SQL_FILTER_NOT_CONTAINS_COMMENT_DISABLE );\n }\n\n if ( filter.containsSortBy( ) )\n {\n strOrderBy = getOrderBy( filter.getSortBy( ) );\n }\n\n String strSQL = SuggestUtils.buildRequestWithFilter( SQL_QUERY_SELECT_SUGGEST_SUBMIT_BY_FILTER, listStrFilter,\n strOrderBy );\n DAOUtil daoUtil = new DAOUtil( strSQL, plugin );\n int nIndex = 1;\n\n if ( filter.containsIdSuggestSubmit( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggestSubmit( ) );\n nIndex++;\n }\n\n if ( filter.containsIdSuggest( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggest( ) );\n nIndex++;\n }\n\n if ( filter.containsIdSuggestSubmitState( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdSuggestSubmitState( ) );\n nIndex++;\n }\n\n if ( filter.containsIdCategory( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdCategory( ) );\n nIndex++;\n }\n\n if ( filter.containsDateFirst( ) )\n {\n daoUtil.setTimestamp( nIndex, filter.getDateFirst( ) );\n nIndex++;\n }\n\n if ( filter.containsDateLast( ) )\n {\n daoUtil.setTimestamp( nIndex, filter.getDateLast( ) );\n nIndex++;\n }\n\n if ( filter.containsIdReported( ) )\n {\n daoUtil.setBoolean( nIndex, filter.convertIdBoolean( filter.getIdReported( ) ) );\n nIndex++;\n }\n\n if ( filter.containsNumberVote( ) )\n {\n daoUtil.setInt( nIndex, filter.getNumberVote( ) );\n nIndex++;\n }\n\n if ( filter.containsIdPinned( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdPinned( ) );\n nIndex++;\n }\n\n if ( filter.containsIdType( ) )\n {\n daoUtil.setInt( nIndex, filter.getIdType( ) );\n nIndex++;\n }\n\n daoUtil.executeQuery( );\n\n while ( daoUtil.next( ) )\n {\n suggestSubmitList.add( getRow( daoUtil ) );\n }\n\n daoUtil.free( );\n\n return suggestSubmitList;\n }", "BuildFilter defaultFilter();", "public void setFilter(Expression filter) {\n this.filter = filter;\n }", "public void filterTable(String filter) {\n\t\tif (fullBackup.isEmpty() || fullBackup == null) {\n\t\t\tfullBackup.addAll(list);\n\t\t}\n\n\t\t// always clear selected items\n\t\tselectionModel.clear();\n\t\tlist.clear();\n\n\t\tif (filter.equalsIgnoreCase(\"\")) {\n\t\t\tlist.addAll(fullBackup);\n\t\t} else {\n\t\t\tfor (Attribute attr : fullBackup){\n\t\t\t\t// store facility by filter\n\t\t\t\tif (attr.getFriendlyName().toLowerCase().startsWith(filter.toLowerCase())) {\n\t\t\t\t\tlist.add(attr);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\n\t\tdataProvider.flush();\n\t\tdataProvider.refresh();\n\t\tloaderImage.loadingFinished();\n\n\t}", "List<ArticleDTO> getFilteredByTwo(ArticlesFilterDTO filterDTO) throws ApiException;", "String getFilter();", "private Filter readFilter() {\n final Stack<Node> expressionStack = new Stack<Node>();\n\n // Employ the shunting-yard algorithm to parse into reverse polish notation,\n // where the operands are filter components and the operators are the\n // logical AND and OR operators. This algorithm ensures that operator\n // precedence and parentheses are respected.\n final List<Node> reversePolish = new ArrayList<Node>();\n for (String word = readWord(); word != null; word = readWord()) {\n if (word.equalsIgnoreCase(\"and\") || word.equalsIgnoreCase(\"or\")) {\n final OperatorNode currentOperator;\n if (word.equalsIgnoreCase(\"and\")) {\n currentOperator = new OperatorNode(Operator.AND, markPos);\n } else {\n currentOperator = new OperatorNode(Operator.OR, markPos);\n }\n while (!expressionStack.empty() && (expressionStack.peek() instanceof OperatorNode)) {\n final OperatorNode previousOperator = (OperatorNode) expressionStack.peek();\n if (previousOperator.getPrecedence() < currentOperator.getPrecedence()) {\n break;\n }\n reversePolish.add(expressionStack.pop());\n }\n expressionStack.push(currentOperator);\n } else if (word.equals(\"(\")) {\n expressionStack.push(new LeftParenthesisNode(markPos));\n } else if (word.equals(\")\")) {\n while (!expressionStack.empty() && !(expressionStack.peek() instanceof LeftParenthesisNode)) {\n reversePolish.add(expressionStack.pop());\n }\n if (expressionStack.empty()) {\n final String msg =\n String.format(\"No opening parenthesis matching closing \" +\n \"parenthesis at position %d\", markPos);\n throw new IllegalArgumentException(msg);\n }\n expressionStack.pop();\n } else {\n rewind();\n final int pos = currentPos;\n final Filter filterComponent = readFilterComponent();\n reversePolish.add(new FilterNode(filterComponent, pos));\n }\n }\n\n while (!expressionStack.empty()) {\n final Node node = expressionStack.pop();\n if (node instanceof LeftParenthesisNode) {\n final String msg =\n String.format(\"No closing parenthesis matching opening \" +\n \"parenthesis at position %d\", node.getPos());\n throw new IllegalArgumentException(msg);\n }\n reversePolish.add(node);\n }\n\n // Evaluate the reverse polish notation to create a single complex filter.\n final Stack<FilterNode> filterStack = new Stack<FilterNode>();\n for (final Node node : reversePolish) {\n if (node instanceof OperatorNode) {\n final FilterNode rightOperand = filterStack.pop();\n final FilterNode leftOperand = filterStack.pop();\n final OperatorNode operatorNode = (OperatorNode)node;\n if (operatorNode.getOperator().equals(Operator.AND)) {\n final Filter filter = createAndFilter(\n Arrays.asList(leftOperand.getFilterComponent(),\n rightOperand.getFilterComponent()));\n filterStack.push(new FilterNode(filter, leftOperand.getPos()));\n } else {\n final Filter filter = createOrFilter(\n Arrays.asList(leftOperand.getFilterComponent(),\n rightOperand.getFilterComponent()));\n filterStack.push(new FilterNode(filter, leftOperand.getPos()));\n }\n } else {\n filterStack.push((FilterNode)node);\n }\n }\n\n if (filterStack.size() == 0) {\n final String msg = String.format(\"Empty filter expression\");\n throw new IllegalArgumentException(msg);\n }\n else if (filterStack.size() > 1) {\n final String msg = String.format(\n \"Unexpected characters at position %d\", expressionStack.get(1).pos);\n throw new IllegalArgumentException(msg);\n }\n\n return filterStack.get(0).filterComponent;\n }", "public void onUpdateFilters(SearchFilter newFilter) {\n filter.setSort(newFilter.getSort());\n filter.setBegin_date(newFilter.getBegin_date());\n filter.setNewsDeskOpts(newFilter.getNewsDeskOpts());\n gvResults.clearOnScrollListeners();\n setUpRecycler();\n fetchArticles(0,true);\n }", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n if (constraint.length() == 0) {\n array = arrayList_copy;\n\n } else {\n\n if (filterType == 0) {\n array = getItemFilter(constraint.toString().toLowerCase());\n } else {\n array = getCodeFilter(constraint.toString().toLowerCase());\n }\n\n }\n FilterResults filterResults = new FilterResults();\n filterResults.values = array;\n\n\n return filterResults;\n }", "@Override\n public void visit(final OpFilter opFilter) {\n if (LOG.isDebugEnabled()) {\n LOG.debug(\"Starting visiting OpFilter\");\n }\n addOp(OpFilter.filterBy(opFilter.getExprs(), rewriteOp1(opFilter)));\n }", "public void addBusinessFilterToMigRelations(ViewerFilter filter);", "public void addFilter(Filter filter){\n removeEndQuery();\n setMainQuery(getMainQuery()+filter.getFilter()+\"}\");\n setCountQuery(getCountQuery()+filter.getFilter()+\"}\");\n }", "public static void filter(Object filterBy, Object filterValue) {\n\n\t\tif(filterBy.equals(\"Course\")) { // Filter by course\n\n\t\t\tArrayList<QuizData> list = new ArrayList<QuizData>();\n\n\t\t\tArrayList<QuizData> quizList = BrowserData.quizList();\n\n\t\t\tfor (int i = 0; i < quizList.size(); i++) {\n\n\t\t\t\tif(filterValue.equals(quizList.get(i).getCourse())) {\n\n\t\t\t\t\tlist.add(quizList.get(i));\n\n\t\t\t\t}\n\n\t\t\t}\n\n\t\t\tresultList = list;\n\t\t\tResult.instance().draw();\n\t\t}\n\n\t\tif(filterBy.equals(\"Author\")) { // Filter by author\n\n\t\t\tArrayList<QuizData> list = new ArrayList<QuizData>();\n\n\t\t\tArrayList<QuizData> quizList = BrowserData.quizList();\n\n\t\t\tfor (int i = 0; i < quizList.size(); i++) {\n\n\t\t\t\tif(filterValue.equals(quizList.get(i).getUser().getLastName() + \", \" + quizList.get(i).getUser().getFirstName())) {\n\n\t\t\t\t\tlist.add(quizList.get(i));\n\n\t\t\t\t}\n\n\t\t\t}\n\n\t\t\tresultList = list;\n\t\t\tResult.instance().draw();\n\n\t\t}\n\n\t\tif(filterBy.equals(\"None\")) { // Apply no filter\n\n\t\t\tresultList = BrowserData.quizList();\n\t\t\tResult.instance().draw();\n\n\t\t}\n\n\t}", "public List<Cuenta> buscarCuentasList(Map filtro);", "public Collection<Object> getOrderedTestNames(Map<String,String> filter) throws\n NEDSSSystemException , InvalidSRTFilterKeysException {\n\n\n\n ArrayList<Object> returnSet = null;\n String programArea = null;\n String condition = null;\n String orderingFacility = null;\n String orderedTest = null;\n\n programArea = (String) filter.get(SRTFilterKeys.PROGRAM_AREA_CODE);\n condition = (String) filter.get(SRTFilterKeys.CONDITION_CODE);\n orderingFacility = (String) filter.get(SRTFilterKeys.REPORTING_FACILITY_ID);\n orderedTest = (String) filter.get(SRTFilterKeys.ORDERED_TEST_CODE);\n\n if (filter.size() == 1) {\n if (orderingFacility != null)\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByOrderingFacility(orderingFacility);\n else {\n throw new InvalidSRTFilterKeysException(\"Invalid Filter Key Exception\");\n\n }\n }\n else\n {\n if (programArea != null && orderingFacility != null)\n {\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByPA(programArea, orderingFacility);\n if(returnSet == null)\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByPA(programArea, \"DEFAULT\");\n }\n\n else if (condition != null && orderingFacility != null)\n {\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByCondition(condition, orderingFacility);\n if(returnSet == null)\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByCondition(condition, \"DEFAULT\");\n }\n\n else if(orderedTest != null && orderingFacility != null)\n {\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByOrderingFacilityAndTest(orderingFacility, orderedTest);\n if(returnSet == null)\n returnSet = (ArrayList<Object> ) getOrderedTestNamesByOrderingFacilityAndTest(\"DEFAULT\",orderedTest);\n }\n else\n throw new NEDSSSystemException(\"Invalid Filter Key Exception\");\n\n }\n\n if (returnSet == null)\n return getOrderedTestNamesByOrderingFacility(\"DEFAULT\");\n else\n return returnSet;\n}", "StandardFilterBuilder standardFilter(int count);", "public void addFilterToComboRO(ViewerFilter filter);", "@SuppressWarnings(\"unchecked\")\n\tpublic static List<Filter> getFilters(AgentContext ctx) {\n\t\tString filtrs = ConfigurationManager.getProperty(Agent.getPropertyName(AGENT_GROUP_NAME, \"list\"));\n\t\tif (filtrs == null) \n {\n filtrs = DEFAULT_FILTERS;\n log.info(LogManager.getHeader(null, \"Filters is null!!!\", null));\n }\n else\n log.info(LogManager.getHeader(null, \"Filters is NOT null!!!\", null));\n\t\tList<String> filters = Arrays.asList(filtrs.split(\",\"));\n\t\tList<Filter> list = new ArrayList<Filter>();\n\t\tfor (String string : filters) {\n\t\t\ttry {\n\t\t\t log.info(LogManager.getHeader(null,\"Get Filters #\",string));\n Class cls = Class.forName(string.trim());\n\t\t\t\tObject obj = cls.newInstance();\n\t\t\t\tif (obj instanceof Filter) {\n\t\t\t\t\tFilter m = (Filter) obj;\n\t\t\t\t\tm.setContext(ctx);\n\t\t\t\t\tlist.add(m);\n\t\t\t\t}\n\t\t\t} catch (ClassNotFoundException e) {\n\t\t\t\tlog.info(LogManager.getHeader(null, \"oaidriver_error\",\n \"Class \"+string.trim()+\" not found\"),e);\n\t\t\t} catch (InstantiationException e) {\n\t\t\t\tlog.info(LogManager.getHeader(null, \"oaidriver_error\",\n\t\t\t\t\t\t\"Impossible to create instance of \"+string.trim()),e);\n\t\t\t} catch (IllegalAccessException e) {\n\t\t\t\tlog.info(LogManager.getHeader(null, \"oaidriver_error\",\n\t\t\t\t\t\t\"Class \"+string.trim()+\" doesn't have empty constructor\"),e);\n\t\t\t}\n\t\t}\n\t\treturn list;\n }", "private void processFilterFlag(String filter) {\r\n\t\tif (filter.equals(\"none\") == true) {\r\n\t\t\tSystem.out.println(\"Removing board filter.\");\r\n\t\t\tresults.removeFilter();\r\n\t\t\treturn;\r\n\t\t}\r\n\t\tchar ch;\r\n\t\tint i = 0;\r\n\t\twhile (i < filter.length()) {\r\n\t\t\tch = Character.toLowerCase(filter.charAt(i));\r\n\t\t\tif (ch == '*') {\r\n\t\t\t\ti++;\r\n\t\t\t} else if(ch >= 'a' && ch <= 'z') {\r\n\t\t\t\tint trailing = (filter.length() - 1) - i;\r\n\t\t\t\tSystem.out.format(\"Added filter: %d%c%d%n\", i, ch, trailing);\r\n\t\t\t\tresults.addFilter(i, ch, trailing);\r\n\t\t\t\treturn;\t\t\t\t\r\n\t\t\t} else {\r\n\t\t\t\tbreak;\r\n\t\t\t}\r\n\t\t}\r\n\t\tSystem.out.println(\"Board filter syntax error!\");\r\n\t\tSystem.out.println(\"0 or more '*'s followed by 1 lower case character, followed by 0 or more stars.\");\r\n\t}", "private HarvestedCollectionRest parseHarvestedCollectionRest(Context context,\n HttpServletRequest request,\n Collection collection) throws SQLException {\n ObjectMapper mapper = new ObjectMapper();\n HarvestedCollectionRest harvestedCollectionRest;\n\n try {\n ServletInputStream input = request.getInputStream();\n harvestedCollectionRest = mapper.readValue(input, HarvestedCollectionRest.class);\n } catch (IOException e) {\n throw new UnprocessableEntityException(\"Error parsing request body: \" + e.toString(), e);\n }\n\n return harvestedCollectionRest;\n }", "void filterChanged(String filter) {\n if (filter.isEmpty()) {\n treeView.setRoot(rootTreeItem);\n } else {\n TreeItem<FilePath> filteredRoot = createTreeRoot();\n filter(rootTreeItem, filter, filteredRoot);\n treeView.setRoot(filteredRoot);\n }\n }", "void onFilterChanged(ArticleFilter filter);", "@Override\r\n public Page<T> filter(U filter)\r\n {\r\n Class<T> T = returnedClass();\r\n CriteriaBuilder cb = getEm().getCriteriaBuilder();\r\n CriteriaQuery<T> criteriaQuery = cb.createQuery(T);\r\n CriteriaQuery<Long> criteriaQueryCount = cb.createQuery(Long.class);\r\n Root<T> entity = criteriaQuery.from(T);\r\n criteriaQueryCount.select(cb.count(entity));\r\n criteriaQuery.select(entity);\r\n \r\n // collect all filters relevant for affected entity\r\n List<Object> filters = new ArrayList<Object>();\r\n getPreFilters(filters, T, filter);\r\n \r\n filters.add(filter);\r\n List<Hint> hints = new ArrayList<Hint>();\r\n \r\n if (!filters.isEmpty()) {\r\n List<Predicate> filterPredicates = new ArrayList<Predicate>();\r\n for (Object queryCriteria : filters) {\r\n \r\n List<Predicate> orPredicates = new ArrayList<Predicate>();\r\n List<Predicate> andPredicates = new ArrayList<Predicate>();\r\n FilterContextImpl<T> filterContext = new FilterContextImpl<T>(entity, criteriaQuery, getEm(), queryCriteria);\r\n hints.addAll(filterContext.getHints());\r\n \r\n List<Field> fields = AbstractFilteringRepository.getInheritedPrivateFields(queryCriteria.getClass());\r\n for (Field field : fields) {\r\n // I want to skip static fields and fields which are cared of in different(specific way)\r\n if (!Modifier.isStatic(field.getModifiers()) && !ignoredFields.contains(field.getName())) {\r\n if (!field.isAccessible()) {\r\n field.setAccessible(true);\r\n }\r\n \r\n /**\r\n * Determine field path\r\n */\r\n // anottaion specified path has always highest priority, so is processed in the first place processing\r\n FieldPath fieldPathAnnotation = field.getAnnotation(FieldPath.class);\r\n Field f;\r\n if (fieldPathAnnotation != null && StringUtils.isNotBlank(fieldPathAnnotation.value())) {\r\n f = FieldUtils.getField(T, StringUtils.substringBefore(fieldPathAnnotation.value(), FieldPath.FIELD_PATH_SEPARATOR), true);\r\n } else {\r\n f = FieldUtils.getField(T, StringUtils.substringBefore(field.getName(), StructuredPathFactory.FILTER_PATH_SEPARATOR), true);\r\n }\r\n \r\n // tries to find CustmoProcessor annotation or some annotation metaannotated by custom processor\r\n CustomProcessor processor = field.getAnnotation(CustomProcessor.class);\r\n if (processor == null) {\r\n processor = getMetaAnnotation(CustomProcessor.class, field);\r\n }\r\n \r\n ProcessorContext<T> processorContext = filterContext.getProcessorContext(andPredicates, orPredicates, field);\r\n Object filterFieldValue = getFilterFieldValue(field, queryCriteria);\r\n if (processor == null && f != null) {\r\n processTypes(filterFieldValue, processorContext);\r\n // If field is not pressent in Entity, it needs special care\r\n } else {\r\n Class<CustomFieldProcessor<T, ?>> processorClass = null;\r\n if (processor != null) {\r\n processorClass = (Class<CustomFieldProcessor<T, ?>>) processor.value();\r\n processCustomFields(filterFieldValue, processorContext, processorClass);\r\n } else {\r\n if (!processCustomTypes(filterFieldValue, processorContext)) {\r\n if (shouldCheck(processorContext.getField())) {\r\n LOG.info(\"Field \\'\" + processorContext.getField().getName() + \"\\' from \"\r\n + processorContext.getField().getDeclaringClass().getSimpleName()\r\n + \" wasn't handled. \");\r\n throw new UnsupportedOperationException(\"Custom filter fields not supported in \"\r\n + processorContext.getField().getDeclaringClass().getSimpleName()\r\n + \", required field: \" + processorContext.getField().getName());\r\n } else {\r\n LOG.info(\"Field \\'\" + processorContext.getField().getName() + \"\\' from \"\r\n + processorContext.getField().getDeclaringClass().getSimpleName()\r\n + \" marked with @Unchecked annotation wasn't handled. \");\r\n }\r\n }\r\n }\r\n }\r\n }\r\n }\r\n if (!andPredicates.isEmpty() || !orPredicates.isEmpty()) {\r\n Predicate filterPredicate = null;\r\n if (!andPredicates.isEmpty()) {\r\n Predicate andPredicate = cb.and(andPredicates.toArray(new Predicate[1]));\r\n filterPredicate = andPredicate;\r\n }\r\n if (!orPredicates.isEmpty()) {\r\n Predicate orPredicate = cb.or(orPredicates.toArray(new Predicate[1]));\r\n if (filterPredicate != null) {\r\n filterPredicate = cb.and(filterPredicate, orPredicate);\r\n } else {\r\n filterPredicate = orPredicate;\r\n }\r\n }\r\n filterPredicates.add(filterPredicate);\r\n }\r\n }\r\n if (!filterPredicates.isEmpty()) {\r\n Predicate finalPredicate = cb.and(filterPredicates.toArray(new Predicate[1]));\r\n criteriaQuery.where(finalPredicate);\r\n criteriaQueryCount.where(finalPredicate);\r\n }\r\n }\r\n \r\n \r\n TypedQuery<T> query = getEm().createQuery(criteriaQuery);\r\n TypedQuery<Long> queryCount = getEm().createQuery(criteriaQueryCount);\r\n if (filter != null && filter.getPageSize() > 0) {\r\n query = query.setFirstResult(filter.getOffset());\r\n query = query.setMaxResults(filter.getPageSize());\r\n }\r\n // add hints\r\n if (!hints.isEmpty()) {\r\n for (Hint hint : hints) {\r\n query.setHint(hint.getName(), hint.getValue());\r\n queryCount.setHint(hint.getName(), hint.getValue());\r\n }\r\n }\r\n \r\n \r\n PageImpl<T> result = new PageImpl<T>(query.getResultList(), filter, queryCount.getSingleResult().intValue());\r\n return result;\r\n }", "public void parseNode(INode node, TreeItem<Object> root, String filter) {\n\n TreeItem<Object> nodeItem = new TreeItem<>(node);\n root.getChildren().add(nodeItem);\n\n if (this.showEdges) {\n\n TreeItem<Object> edgeTI = new TreeItem<>(node + \"Edges (\"\n + node.getEdges().size() + \")\");\n nodeItem.getChildren().add(edgeTI);\n\n for (IEdge edge : node.getEdges()) {\n\n this.parseEdge(edge, edgeTI, filter);\n }\n }\n if (this.showHyperEdges) {\n TreeItem<Object> hyperItem = new TreeItem<>(node\n + \"HyperEdges (\" + node.getHyperEdges().size() + \")\");\n nodeItem.getChildren().add(hyperItem);\n \n for (IHyperEdge he : node.getHyperEdges()) {\n \n this.parseHyperEdge(he, hyperItem, filter);\n }\n }\n\n }", "public ParticleMeasure filter(final Filter filter)\n\t\t{\n\t\tParticleMeasure out=new ParticleMeasure();\n\t\t\n\t\t//Copy all the columns\n\t\tout.columns.addAll(columns);\n\t\t\n\t\t//Copy all frames\n\t\tfor(Map.Entry<EvDecimal, FrameInfo> f:frameInfo.entrySet())\n\t\t\tif(filter.acceptFrame(f.getKey()))\n\t\t\t\t{\n\t\t\t\t//Create place-holder for frame\n\t\t\t\tfinal FrameInfo oldInfo=f.getValue();\n\t\t\t\tfinal FrameInfo newInfo=new FrameInfo();\n\t\t\t\tout.frameInfo.put(f.getKey(), newInfo);\n\n\t\t\t\t//Filter need to execute lazily as well\n\t\t\t\tnewInfo.calcInfo=new CalcInfo()\n\t\t\t\t\t{\n\t\t\t\t\tpublic void calc()\n\t\t\t\t\t\t{\n\t\t\t\t\t\t//Execute calculation if not done already\n\t\t\t\t\t\tif(oldInfo.calcInfo!=null)\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\toldInfo.calcInfo.calc();\n\t\t\t\t\t\t\toldInfo.calcInfo=null;\n\t\t\t\t\t\t\t}\n\n\t\t\t\t\t\t//Filter particles\n\t\t\t\t\t\tfor(int id:oldInfo.keySet())\n\t\t\t\t\t\t\t{\n\t\t\t\t\t\t\tParticleInfo pInfo=oldInfo.get(id);\n\t\t\t\t\t\t\tif(filter.acceptParticle(id, pInfo))\n\t\t\t\t\t\t\t\tnewInfo.put(id,pInfo);\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t};\n\t\t\t\t}\n\t\t\n\t\treturn out;\n\t\t}", "@Override\n public int filterOrder() {\n return 1;\n }", "@Override\n public int filterOrder() {\n return 1;\n }", "@Override\n protected FilterResults performFiltering(CharSequence constraint) {\n List<EnquiryModel> filteredList = new ArrayList<>();\n\n if(constraint == null || constraint.length() == 0){\n //show all data\n filteredList.addAll(enquiryAll);\n }else {\n //filter using keys\n String filterPattern = constraint.toString().toLowerCase().trim();\n for(EnquiryModel enquiryModel : enquiryAll){\n if(enquiryModel.getUser_name().toLowerCase().contains(filterPattern) || enquiryModel.getUser_email().toLowerCase().contains(filterPattern)|| enquiryModel.getHostel_name().contains(filterPattern)|| enquiryModel.getEnquiry_status().contains(filterPattern)){\n filteredList.add(enquiryModel); //store those enquiry whose hostel name contains list as asked.\n }\n }\n }\n\n FilterResults filterResults = new FilterResults();\n filterResults.values = filteredList;\n\n return filterResults;\n }" ]
[ "0.5676743", "0.56606954", "0.5529514", "0.5499255", "0.52744514", "0.52522904", "0.5252185", "0.5125889", "0.50905716", "0.50580895", "0.50300604", "0.5029987", "0.5012422", "0.5011471", "0.49935886", "0.49644378", "0.4929734", "0.49183205", "0.49080837", "0.490734", "0.4906371", "0.49022862", "0.48951715", "0.48680532", "0.48316234", "0.48160565", "0.48127806", "0.4809652", "0.4804861", "0.48037004", "0.47895086", "0.4780263", "0.47794256", "0.4760222", "0.4751442", "0.47480118", "0.4744053", "0.4740471", "0.47299674", "0.47141758", "0.47120655", "0.47057104", "0.47033027", "0.4692813", "0.46845013", "0.46808258", "0.46804082", "0.4676244", "0.46669617", "0.46653494", "0.46580365", "0.46546823", "0.46536183", "0.46527958", "0.46498287", "0.4643036", "0.4638266", "0.4638252", "0.46348745", "0.46293408", "0.46288607", "0.46249616", "0.4619385", "0.46154788", "0.4613507", "0.46128166", "0.46110097", "0.46096718", "0.4609482", "0.46081182", "0.46081182", "0.46026996", "0.46008795", "0.4600495", "0.459849", "0.45908564", "0.45900908", "0.45892173", "0.458898", "0.45859104", "0.45809245", "0.45790356", "0.45734197", "0.45728484", "0.45724988", "0.45707148", "0.45700276", "0.4566462", "0.45653164", "0.45636773", "0.45634532", "0.45587826", "0.45467088", "0.45444223", "0.45299965", "0.45282656", "0.45268628", "0.45255548", "0.45255548", "0.4523261" ]
0.6305962
0
Get the results that was parsed
public Collection<T> getResults();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Result getResults()\r\n {\r\n return result;\r\n }", "public String getResults() {\r\n return returnObject.getResults();\r\n }", "@Override\n\tprotected void parseResult() {\n\t\t\n\t}", "public List<CorpusSearchHit> getResult() {\n return result;\n }", "CParserResult getParserResult();", "public Map<String, Result> getResults() {\n return results;\n }", "@Override\n @XmlElement(name = \"result\", required = true)\n public Collection<Result> getResults() {\n return results = nonNullCollection(results, Result.class);\n }", "public void getResults()\n\t{\n\t\tThread mOutReader = new Thread()\n\t\t{\n\t\t\tpublic void run()\n\t\t\t{\n\t\t\t\ttry\n\t\t\t\t{\n\t\t\t\t\tBufferedReader br = new BufferedReader(new InputStreamReader(mProcess.getInputStream()));\n\t\t\t\t\tString line = br.readLine();\n\t\t\t\t\twhile ((!isInterrupted() && line != null))\n\t\t\t\t\t{\n\t\t\t\t\t\tline = line.trim();\n\t\t\t\t\t\tmResults.add(line);\n\t\t\t\t\t\tline = br.readLine();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tcatch (InterruptedIOException e)\n\t\t\t\t{\n\t\t\t\t}\n\t\t\t\tcatch (Exception e)\n\t\t\t\t{\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\n\t\t//we will process the error stream just in case\n\t\tThread mErrReader = new Thread()\n\t\t{\n\t\t\tpublic void run()\n\t\t\t{\n\t\t\t\ttry\n\t\t\t\t{\n\t\t\t\t\tBufferedReader br = new BufferedReader(new InputStreamReader(mProcess.getErrorStream()));\n\t\t\t\t\tString line = br.readLine();\n\t\t\t\t\twhile ((!isInterrupted() && line != null))\n\t\t\t\t\t{\n\t\t\t\t\t\tline = line.trim();\n\t\t\t\t\t\tSystem.out.println(line);\n\t\t\t\t\t\tline = br.readLine();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tcatch (InterruptedIOException e)\n\t\t\t\t{\n\t\t\t\t}\n\t\t\t\tcatch (Exception e)\n\t\t\t\t{\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\n\t\tmOutReader.start();\n\t\tmErrReader.start();\n\n\t\t//wait for process to end.\n\t\ttry\n\t\t{\n\t\t\tmProcess.waitFor();\n\t\t}\n\t\tcatch (Exception e)\n\t\t{\n\t\t\tSystem.err.println(\"process exception\");\n\t\t}\n\t\tmFinished = true;\n\t}", "List<T> getResults();", "public void getResults() {\n\t\tSystem.out.println(\"|V| : \" + g.getV());\n\t\tSystem.out.println(\"|E| : \" + g.getE());\n\t\tSystem.out.println(\"Max flow : \" + g.getVertex(sink).e);\n\t\tSystem.out.println(\"Run time : \" + (System.currentTimeMillis()-timeStart) + \" ms\"+\"\\n\");\n\t}", "public NMapRun getResult() {\n\t\tOnePassParser parser = new OnePassParser() ;\n\t\tNMapRun nmapRun = parser.parse(outFilePath, OnePassParser.FILE_NAME_INPUT ) ;\n\t\treturn nmapRun ;\n\t}", "public void processResults() {\r\n try {\r\n rm5 = new Process(new File(_corePath.RAPID_MINER_PROCESS_XML));\r\n IOContainer ioResult = rm5.run();\r\n ExampleSet resultSet;\r\n int num_rules = 0;\r\n if (ioResult.getElementAt(0) instanceof ExampleSet) {\r\n resultSet = (ExampleSet) ioResult.getElementAt(0);\r\n for (int i = 0; i <= resultSet.size() - 1; i++) {\r\n if ((resultSet.getExample(i).get(\"Premise Items\").equals(1)) && (resultSet.getExample(i).get(\"Conclusion Items\").equals(1))) {\r\n num_rules++;\r\n results += \"<ul><li title=\\\"Premise\\\">\" + resultSet.getExample(i).get(\"Premise\") + \"</li>\"\r\n + \"<li title=\\\"Conclusion\\\">\" + resultSet.getExample(i).get(\"Conclusion\") + \"</li>\"\r\n + \"<li title=\\\"Confidence\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Confidence\")) + \"</li>\"\r\n + \"<li title=\\\"Conviction\\\" class=\\\"metrics\\\">\";\r\n\r\n if (resultSet.getExample(i).get(\"Conviction\").equals(\"Infinity\")) {\r\n results += resultSet.getExample(i).get(\"Conviction\");\r\n } else {\r\n results += String.format(\"%f%n\", resultSet.getExample(i).get(\"Conviction\"));\r\n }\r\n\r\n results += \"</li>\"\r\n + \"<li title=\\\"Gain\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Gain\")) + \"</li>\"\r\n + \"<li title=\\\"Laplace\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Laplace\")) + \"</li>\"\r\n + \"<li title=\\\"Lift\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Lift\")) + \"</li>\"\r\n + \"<li title=\\\"Ps\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Ps\")) + \"</li>\"\r\n + \"<li title=\\\"Total Support\\\" class=\\\"metrics\\\">\" + String.format(\"%f%n\", resultSet.getExample(i).get(\"Total Support\")) + \"</li><li class=\\\"num_rules\\\">\" + num_rules + \"</li></ul>\";\r\n } else {\r\n break;\r\n }\r\n }\r\n } else {\r\n results = \"No results found.\";\r\n }\r\n\r\n results = results.replace(\"[\", \"\");\r\n results = results.replace(\"]\", \"\");\r\n\r\n\r\n } catch (OperatorException ex) {\r\n Logger.getLogger(Core.class.getName()).log(Level.SEVERE, null, ex);\r\n } catch (IOException ex) {\r\n Logger.getLogger(Core.class.getName()).log(Level.SEVERE, null, ex);\r\n } catch (XMLException ex) {\r\n Logger.getLogger(Core.class.getName()).log(Level.SEVERE, null, ex);\r\n }\r\n }", "private static void getResults() {\n\t\t//Variables\n\t\tFile directoryOfChunks = new File(\"output\");\n\t\tFile[] files = directoryOfChunks.listFiles();\n\t\tArrayList<String> filesInFolder = new ArrayList<>();\n\t\tArrayList<String> chunkResults = new ArrayList<>();\n\t\tBufferedReader br = null;\n\t\tReadFromFile rf = new ReadFromFile();\n\n\t\t//Get files from output folder\n\t\tif(directoryOfChunks.exists() && directoryOfChunks.isDirectory()){\n\t\t\tdirectoryName = \"output\";\n\t\t\t//Copy file names into arraylist\n\t\t\tfor (File f: files) {\n\t\t\t\t//Save file names into arraylist.\n\t\t\t\tfilesInFolder.add(f.getName());\n\t\t\t}\n\t\t}\n\t\t//if not a file or directory print error message\n\t\telse{\n\t\t\tSystem.out.println(\"No such file/directory: \" + directoryOfChunks);\n\t\t}\n\n\t\t//for loop to open and read each individual file\n\t\tfor (String file : filesInFolder) {\n\t\t\ttry {\n\n\t\t\t\tFileReader reader = new FileReader(directoryName + \"\\\\\" + file);\n\t\t\t\tbr = new BufferedReader(reader);\n\t\t\t} catch (FileNotFoundException e1) {\n\t\t\t\te1.printStackTrace();\n\t\t\t}\n\t\t\tchunkResults.addAll(rf.readFromChunk(br));\n\t\t}\n\n\t\t//Call sanitizeAndSplit\n\t\tsanitizeAndSplit(chunkResults);\n\t}", "public Map<String, StepResult> getResults()\n {\n return results;\n }", "public List getResult() {\n // Flush remaining text content in case the last text segment is\n // outside an element.\n try {\n this.flushCharacters();\n }\n catch (SAXException e) { /* Ignore... */ }\n return this.getDetachedContent(dummyRoot);\n }", "public IScapSyncSearchResult[] getResults();", "public ArrayList<R> getResults() {\n return results;\n }", "@Override\r\n\tpublic Object getParseResult() {\n\t\treturn this;\r\n\t}", "@Override\r\n\tpublic Object getParseResult() {\n\t\treturn this;\r\n\t}", "public String getResultsString()\r\n {\r\n String ResultsString = null;\r\n try\r\n {\r\n ResultsString = ResultsDocument.getText(ResultsDocument.getStartPosition().getOffset(),\r\n ResultsDocument.getLength() );\r\n }\r\n catch (BadLocationException InputException)\r\n {\r\n\t System.out.println(\"GrepFrame.getResultsString: Results document not initialised: \"\r\n\t + InputException);\r\n }\r\n return ResultsString;\r\n }", "java.util.List<org.apache.calcite.avatica.proto.Responses.ResultSetResponse> \n getResultsList();", "public List<String> getResult()\n {\n while (!readComplete)\n {\n try\n {\n Thread.sleep(1000);\n }\n catch (InterruptedException ex)\n {\n // swallow and exit;\n }\n }\n return lines;\n }", "java.util.List<entities.Torrent.NodeSearchResult>\n getResultsList();", "public entities.Torrent.NodeSearchResult getResults(int index) {\n if (resultsBuilder_ == null) {\n return results_.get(index);\n } else {\n return resultsBuilder_.getMessage(index);\n }\n }", "@java.lang.Override\n public entities.Torrent.NodeSearchResult getResults(int index) {\n return results_.get(index);\n }", "@Test\n\tvoid getResultsTest() {\n\t\tassertEquals(22, utilities.getResults(-21));\n\t\tassertEquals(20, utilities.getResults(-20));\n\t\tassertEquals(40, utilities.getResults(-19));\n\t\tassertEquals(38, utilities.getResults(-18));\n\t\tassertEquals(22, utilities.getResults(21));\n\t\tassertEquals(20, utilities.getResults(20));\n\t\tassertEquals(22, utilities.getResults(2));\n\t\tassertEquals(22, utilities.getResults(1));\n\t}", "public java.util.List<entities.Torrent.NodeSearchResult> getResultsList() {\n if (resultsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(results_);\n } else {\n return resultsBuilder_.getMessageList();\n }\n }", "public download.Map getResult() {\n return result;\n }", "@Override\r\n\tpublic ArrayList<ArrayList<Value>> getResults(Value[] quad) throws IOException {\n\t\treturn null;\r\n\t}", "public String getAllResults() {\n StringBuilder sb = new StringBuilder();\n for (Map.Entry<String, String> results : resultMap.entrySet()) {\n sb.append(results.getKey().toString() + \" : \" + results.getValue().toString() + \"\\n\");\n }\n return sb.toString();\n }", "public String getGameResults(){\n \treturn this.gameResults;\n }", "public MatchResult getResult() {\n return result;\n }", "static void getResults() throws IOException {\n\t\tint k = 2;\n\t\twhile (k <= 7) {\n\t\t\tint j = 1;\n\t\t\tString line;\n\t\t\tString precision = \"\";\n\t\t\tString recall = \"\";\n\t\t\tString fmeasure = \"\";\n\t\t\tString time = \"\";\n\n\n\t\t\twhile (j <= 10) {\n\t\t\t\tBufferedReader br = new BufferedReader(new FileReader(\n\t\t\t\t\t\tnew File(ConfigManager.getExperimentFolder() + \"M\" + k + \"/Testbeds-\"+j\n\t\t\t\t\t\t\t\t+ \"/Generated/PSL/test/Precision/F1NoTraining.txt\")));\n\n\t\t\t\twhile ((line = br.readLine()) != null) {\n\t\t\t\t\tif (line.contains(\"Precision :\")) {\n\t\t\t\t\t\tprecision += line.replace(\"Precision :\", \"\") + \"\\n\";\n\t\t\t\t\t}\n\t\t\t\t\tif (line.contains(\"Recall:\")) {\n\t\t\t\t\t\trecall += line.replace(\"Recall:\", \"\") + \"\\n\";\n\t\t\t\t\t}\n\t\t\t\t\tif (line.contains(\"Fmeasure:\")) {\n\t\t\t\t\t\tfmeasure += line.replace(\"Fmeasure:\", \"\") + \"\\n\";\n\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t\tif (line.contains(\"Time:\")) {\n\t\t\t\t\t\ttime += line.replace(\"Time:\", \"\") + \"\\n\";\n\t\t\t\t\t}\n\t\t\t\t}\n\n\t\t\t\tj++;\n\t\t\t}\n\n\t\t\tSystem.out.print(precision);\n//\t\t\tSystem.out.print(recall);\n//\t\t\tSystem.out.print(fmeasure);\n//\t\t\tSystem.out.print(time);\n\n\t\t\tk++;\n\t\t}\n\t}", "public Vector getResultObjects() {\n\treturn _vcResults;\n }", "List<GameResult> getAllResults();", "public List<BenchmarkResultSet> getResults() {\n return results;\n }", "protected R getResult() {\n\t\treturn result;\n\t}", "public List getResult() {\n List result = null;\n\n if (this.saxHandler != null) {\n // Retrieve result from SAX content handler.\n result = this.saxHandler.getResult();\n\n // Detach the (non-reusable) SAXHandler instance.\n this.saxHandler = null;\n\n // And get ready for the next transformation.\n this.startDocumentReceived = false;\n }\n return result;\n }", "org.apache.calcite.avatica.proto.Responses.ResultSetResponse getResults(int index);", "public List<Integer> Result()\n\t{\n\t\treturn result;\n\t}", "public ArrayList<Integer> getResults(){\n return results;\n }", "public java.lang.String getActualResults() {\n return actualResults;\n }", "public List<Person> getResults() {\n\t\treturn mResult;\n\t}", "@Override\n \tpublic Object getResult() {\n \t\treturn result;\n \t}", "public ArrayOfFindResult getResults() {\n return results;\n }", "private void readResultSet() throws IOException {\n\n\t\tBufferedReader reader = new BufferedReader(\n\t\t\t\t(new InputStreamReader(new FileInputStream(new File(\"./thrash/\" + fileName)), \"ISO-8859-1\")));\n\n\t\tString line = reader.readLine();\n\n\t\twhile (line != null) {\n\n\t\t\tString rate = line.split(\"rate=\")[1].trim();\n\t\t\tString label = line.split(\"[0-9]\\\\.[0-9]\")[0].trim();\n//\t\t\tString googleDescription = line.split(\"googleDescription=\")[1].split(\"score\")[0].trim();\n\t\t\tString score = line.split(\"score=\")[1].split(\"rate=\")[0].trim();\n\n\t\t\tSpatialObject obj = new SpatialObject(label, Double.parseDouble(rate), Double.parseDouble(score));\n//\t\t\tSystem.out.println(\"Label: \" + label);\n//\t\t\tSystem.out.println(\"Rate: \" + rate);\n//\t\t\tSystem.out.println(\"Score: \" + score);\n//\t\t\tSpatialObject idealObj = new SpatialObject(googleDescription, Double.parseDouble(rate), Double.parseDouble(rate));\n\t\t\tSpatialObject idealObj = new SpatialObject(label, Double.parseDouble(rate), Double.parseDouble(rate));\n\n\t\t\tresults.add(obj);\n\t\t\tidealResults.add(idealObj);\n\n\t\t\tline = reader.readLine();\n\t\t}\n\n\t\treader.close();\n\t}", "public List<ScorerDoc> get_results(){\n\t\tList<ScorerDoc> docs_array = new ArrayList<ScorerDoc>();\n\t\twhile (!queue.isEmpty())\n\t\t\tdocs_array.add(queue.poll());\n\t\t\n\t\tCollections.reverse(docs_array);\n\t\treturn docs_array;\n\t}", "@java.lang.Override\n public java.util.List<entities.Torrent.NodeSearchResult> getResultsList() {\n return results_;\n }", "public Map<String, Object> getResult() {\n return mRes;\n }", "public String getResult();", "public String getResult();", "public String getResult();", "public Result getResult() {\n return result;\n }", "public Result getResult() {\n return result;\n }", "public ProcessingResult getResult() {\n return new ProcessingResultImpl(documentationMap, configFilesList);\n }", "private ArrayList<SimplifyResult> parseResult(String executionResult) throws IOException {\n\t\t// create buffer readers\n\t\tStringReader stringReader = new StringReader(executionResult);\n\t\tBufferedReader bufferedReader = new BufferedReader(stringReader);\t\t\t\t\n\t\t\n\t\tString line;\n\t\tArrayList<SimplifyResult> results = new ArrayList<SimplifyResult>();\n\t\t\n\t\twhile ((line = bufferedReader.readLine()) != null) {\n\t\t\tif (line.indexOf(\"Invalid\") != -1) {\n\t\t\t\tresults.add(new SimplifyResult(line, SimplifyResult.INVALID));\n\t\t\t}\n\t\t\telse if (line.indexOf(\"Valid\") != -1) {\n\t\t\t\tresults.add(new SimplifyResult(line, SimplifyResult.VALID));\n\t\t\t}\n\t\t\telse if (line.indexOf(\"Unable to open file\") != -1) {\n\t\t\t\tresults.add(new SimplifyResult(line, SimplifyResult.UNABLE_TO_OPEN_FILE));\n\t\t\t}\n\t\t\telse if (line.indexOf(\"Bad input\") != -1) {\n\t\t\t\tresults.add(new SimplifyResult(line, SimplifyResult.BAD_INPUT));\n\t\t\t}\n\t\t\telse if (line.indexOf(\"Sx.ReadError in file\") != -1) {\n\t\t\t\tresults.add(new SimplifyResult(line, SimplifyResult.SYNTAX_ERROR));\n\t\t\t}\n\t\t\tline = bufferedReader.readLine();\n\t\t}\t\t\n\t\t\n\t\treturn results;\n\t}", "public ExecutionResults getExecutionResults() {\n\t\treturn results ;\n\t}", "public void getAllResults()\n {\n for(String module: modules.keySet())\n {\n getResults(module);\n }\n }", "@java.lang.Override\n public entities.Torrent.NodeSearchResultOrBuilder getResultsOrBuilder(\n int index) {\n return results_.get(index);\n }", "public Object getResults() throws InterruptedException, ExecutionException {\n\t\t\treturn result.get();\n\t}", "public java.util.List<org.apache.calcite.avatica.proto.Responses.ResultSetResponse> getResultsList() {\n if (resultsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(results_);\n } else {\n return resultsBuilder_.getMessageList();\n }\n }", "private void results() {\n\t\t// when the election is not closed,\n\t\ttry{\n\t\t\tMap<String,Integer> results = election.getResultsFromPolls();\n\t\t\t// when the election is closed,\n\n\t\t\tCollection<Integer> values = results.values();\n\t\t\tint totalVotes = 0;\n\n\t\t\tfor(Integer i:values){\n\t\t\t\ttotalVotes += i;\n\t\t\t}\n\t\t\tSystem.out.println(\"Current election results for all polling places.\");\n\t\t\tSystem.out.println(\"NAME PARTY VOTES %\");\n\t\t\tprintResultsHelper(results,totalVotes);\n\n\t\t}catch(UnsupportedOperationException uoe){\n\t\t\tSystem.out.println(\"The election is still open for votes.\");\n\t\t\tSystem.out.println(\"You must close the election before viewing results.\");\n\t\t}\n\t}", "public Object[] gatherResults(VirtualFrame frame){\r\n\t\tObject[] results = new Object[children.length];\r\n\t\tfor(int i = 0; i < results.length; i++){\r\n\t\t\tresults[i] = children[i].executeGeneric(frame);\r\n\t\t}\r\n\t\treturn results;\r\n\t}", "Object[] getElements() {\n\tif (this.results == null) {\n\t\tinitResults();\n\t\tif (this.filterAdvancedScenarios != null) {\n\t\t\tthis.results.setFingerprints(this.filterAdvancedScenarios.isChecked());\n\t\t}\n\t}\n\treturn this.results.getElements();\n}", "private List<List<XMLResults>> loadResults()\n {\n List<List<XMLResults>> ret = new ArrayList<List<XMLResults>>();\n\n for( Platform p : platforms ) {\n\n String platformResultsDir = p.resultsDir+\"/\"+p.libraryDir;\n\n File platformDir = new File(platformResultsDir);\n\n if( !platformDir.exists() ) {\n throw new RuntimeException(\"Results for \"+p.libraryDir+\" do not exist in \"+p.resultsDir);\n }\n\n List<XMLResults> opResults = new ArrayList<XMLResults>();\n\n File[] files = platformDir.listFiles();\n\n for( File f : files ) {\n String fileName = f.getName();\n\n if( fileName.contains(\".csv\")) {\n // extract the operation name\n String stripName = fileName.substring(0,fileName.length()-4);\n\n XMLResults r = new XMLResults();\n r.fileName = stripName;\n r.results = RuntimeResultsCsvIO.read(new File(f.getAbsolutePath()));\n\n opResults.add(r);\n }\n }\n\n ret.add( opResults );\n }\n\n return ret;\n }", "interface Result {\n\n /** The page which contains matches. */\n @NotNull\n Resource getTarget();\n\n /** The content child of the page which contains matches. */\n @NotNull\n Resource getTargetContent();\n\n /** A link that shows the target, including search terms with {@link #PARAMETER_SEARCHTERM} */\n @NotNull\n String getTargetUrl();\n\n /** The title of the search result. */\n @NotNull\n String getTitle();\n\n /** The score of the search result. */\n Float getScore();\n\n /**\n * One or more descendants of {@link #getTarget()} that potentially match the search expression. Mostly useful\n * for generating excerpts; can contain false positives in some search algorithms.\n */\n @NotNull\n List<Resource> getMatches();\n\n /** The fulltext search expression for which this result was found. */\n @NotNull\n String getSearchExpression();\n\n /**\n * A basic excerpt from the matches that demonstrates the occurrences of the terms from {@link\n * #getSearchExpression()} in this result. Might be empty if not applicable (e.g. if the search terms were found\n * in meta information). If there are several matches, we just give one excerpt. You might want to provide your\n * own implementation for that to accommodate for specific requirements.\n *\n * @return a text with the occurrences of the words marked with HTML tag em .\n */\n @NotNull\n String getExcerpt() throws SearchTermParseException;\n }", "public String getResult()\r\n\t{\r\n\t\treturn result;\r\n\t}", "@java.lang.Override\n public com.google.cloud.speech.v2.StreamingRecognitionResult getResults(int index) {\n return results_.get(index);\n }", "public Object[][] exportResults(){\n \tObject[][] results = new Object[calculators.length][];\n \tfor(int i=0; i<calculators.length; i++){\n \t\tICalculator[] row = calculators[i];\n \t\tresults[i] = new Object[row.length];\n \t\tfor(int j=0; j<row.length; j++){\n \t\t\tresults[i][j] = row[j].getResult();\n \t\t}\n \t}\n \treturn results;\n }", "ArrayList<Map<String,Object>> parseQueryResult(Object result) { return null;}", "public List<SimilarResult<T>> getResults() {\n return Collections.unmodifiableList(results);\n }", "public List<String> getResults(){\r\n\t\tList<String> results = new ArrayList<String>();\r\n\t\t\r\n\t\tfor(int i = 0; i < getExcel_file().size(); i++) {\r\n\t\t\tString s = getExcel_file().get(i).toString();\r\n\t\t\tfor(int j = 0; j < columns.size(); j++) {\r\n\t\t\t\ts += \" \" + columns.get(j).getArray().get(i).toString();\r\n\t\t\t}\r\n\t\t\tresults.add(s);\r\n\t\t}\r\n\t\t\r\n\t\treturn results;\r\n\t}", "private String readResult() throws IOException {\n return reader.readLine();\n }", "public String[] getParsed() {\n\t\tif(changed)\n\t\t\treturn lines;\n\t\treturn null;\n\t}", "public List<Result> loadResults() {\n List<Result> results = null;\n try {\n DataBaseBroker dbb = new DataBaseBroker();\n dbb.loadDriver();\n dbb.establishConnection();\n results = dbb.loadResults();\n dbb.commit();\n dbb.closeConnection();\n } catch (Exception ex) {\n Logger.getLogger(GameDBLogic.class.getName()).log(Level.SEVERE, null, ex);\n }\n return results;\n }", "@Override\n public Observable<MainModelImp> getResults() {\n return model.build().getNearbyResult(lat, lon);\n }", "Result getResult();", "static void getResults2(String root) throws IOException {\n\t\tint k = 1;\n\t\twhile (k <= 1) {\n\t\t\tint j = 1;\n\t\t\tString line;\n\t\t\tString multi = \"\";\n\t\t\tSystem.out.println(\"M\" + k);\n\n\t\t\twhile (j <= 10) {\n\t\t\t\tBufferedReader br = new BufferedReader(new FileReader(new File(root\n\t\t\t\t\t\t+ \"M1/M1.1/Testbeds-\" + j + \"/Generated/PSL//test/Precision/multi.txt\")));\n\n\t\t\t\twhile ((line = br.readLine()) != null) {\n\t\t\t\t\tmulti += line;\n\t\t\t\t\tSystem.out.print(line + \",\");\n\n\t\t\t\t}\n\t\t\t\tSystem.out.print(\"\\n\");\n\n\t\t\t\tj++;\n\t\t\t}\n\t\t\tk++;\n\t\t}\n\t}", "public Result getResult() {\n\t\treturn this._result;\n\t}", "@Override\n\tpublic Result getResult() {\n\t\treturn m_Result;\n\t}", "public static void printResults() {\n System.out.println(\" Results: \");\n Crawler.getKeyWordsHits().forEach((keyWord, hitsNumber) -> System.out.println(keyWord + \" : \" + hitsNumber + \";\"));\n System.out.println(\" Total hits: \" + Crawler.getTotalHits());\n\n }", "public void parseResponse();", "static public LinkedList<CUser> getResult() {\r\n\t\treturn result;\r\n\t}", "public com.google.cloud.speech.v2.StreamingRecognitionResult getResults(int index) {\n if (resultsBuilder_ == null) {\n return results_.get(index);\n } else {\n return resultsBuilder_.getMessage(index);\n }\n }", "public java.util.List<com.google.cloud.speech.v2.StreamingRecognitionResult> getResultsList() {\n if (resultsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(results_);\n } else {\n return resultsBuilder_.getMessageList();\n }\n }", "public CurationSet parseAnalysisResults(SeqAnalysisI seqAnalysis);", "public String[] getSummaries() {\n\t\tif (results == null)\n\t\t\treturn null;\n\t\tWebSearchResult[] resultsArray = results.listResults();\n\t\tString[] summaries = new String[resultsArray.length];\n\t\tfor (int i = 0; i < summaries.length; i++) {\n\t\t\tsummaries[i] = resultsArray[i].getSummary();\n\t\t}\n\t\treturn summaries;\n\t}", "java.lang.String getResult();", "public String getResult() {\n return result;\n }", "public String getResult() {\n return result;\n }", "public String getResult() {\n return result;\n }", "public Result() {\n getLatenciesSuccess = new ArrayList<Long>();\n getLatenciesFail = new ArrayList<Long>();\n postLatenciesSuccess = new ArrayList<Long>();\n postLatenciesFail = new ArrayList<Long>();\n getRequestFailNum = 0;\n postRequestFailNum = 0;\n getRequestSuccessNum = 0;\n postRequestSuccessNum = 0;\n// getTimestamps = new ArrayList<Long>();\n// postTimestamps = new ArrayList<Long>();\n }", "@Override\n protected String doInBackground(URL... params) {\n URL searchUrl = params[0];\n String talk2meSearchResults = null;\n try {\n talk2meSearchResults = NetworkUtils.getResponseFromHttpUrl(searchUrl);\n Log.d(TAG, \"talk2meSearchResults is : \" + talk2meSearchResults.toString());\n } catch (IOException e) {\n e.printStackTrace();\n }\n return talk2meSearchResults;\n }", "public String getResult()\n {\n return result;\n }", "java.util.List<? extends entities.Torrent.NodeSearchResultOrBuilder>\n getResultsOrBuilderList();", "public Iterator<Map<String, Object>> getQueryResult() {\n return queryResult;\n }", "private void parse(){\n\t\tfor (Object res : book_results){\n\t\t\tString author = JsonPath.read(res,\"$.name\").toString();\n\t\t\tRole role = new Role(author, \"Author\");\n\t\t\tList<String> books = JsonPath.read(res,\"$./book/author/works_written[*].a:name\");\n\t\t\tmql_map.put(role, books);\n\t\t}\n\t\t\n\t\tfor (Object res : organization_results){\n\t\t\tString businessperson = JsonPath.read(res,\"$.name\").toString();\n\t\t\tRole role = new Role(businessperson, \"Businessperson\");\n\t\t\tList<String> organizations = JsonPath.read(res,\"$./organization/organization_founder/organizations_founded[*].a:name\");\n\t\t\tmql_map.put(role, organizations);\n\t\t}\n\t}", "public java.util.List<? extends entities.Torrent.NodeSearchResultOrBuilder>\n getResultsOrBuilderList() {\n if (resultsBuilder_ != null) {\n return resultsBuilder_.getMessageOrBuilderList();\n } else {\n return java.util.Collections.unmodifiableList(results_);\n }\n }", "@Override\n\tpublic String getResult() {\n\t\treturn result;\n\t}", "private static Map<Task, Double> getResponseFor(Request request) throws ParseException {\n List<Task> availableTasks = new ArrayList<>();// taskDAO.getFutureTasks();\n Byom bakshi = instantiateSatyanveshi();\n return bakshi.getScoresMap(availableTasks, request);\n }" ]
[ "0.67480385", "0.65574604", "0.6509368", "0.6476393", "0.6461029", "0.6429122", "0.63472384", "0.6341619", "0.62874496", "0.6242029", "0.6240632", "0.617057", "0.616361", "0.6141654", "0.61407506", "0.611485", "0.6105356", "0.6104801", "0.6104801", "0.60175717", "0.5990918", "0.5971741", "0.5940445", "0.59335375", "0.5931966", "0.59036344", "0.58980095", "0.5897904", "0.58894366", "0.5864483", "0.58555454", "0.5854134", "0.58512056", "0.5832658", "0.5814004", "0.57782835", "0.5775541", "0.5748195", "0.5742921", "0.5737341", "0.5735743", "0.5731364", "0.5723917", "0.572388", "0.5717503", "0.5711278", "0.5691347", "0.56793344", "0.56610817", "0.56597406", "0.56597406", "0.56597406", "0.56580454", "0.5654696", "0.5653568", "0.56496733", "0.5635862", "0.5615911", "0.56114024", "0.56095594", "0.5596444", "0.5593618", "0.5580033", "0.5579958", "0.55792725", "0.5578103", "0.55733377", "0.55712545", "0.5560971", "0.5560076", "0.5554673", "0.55487543", "0.55461246", "0.5537058", "0.5522325", "0.55202997", "0.5513659", "0.550736", "0.5495217", "0.549346", "0.54924905", "0.5474826", "0.54740983", "0.54722816", "0.5462433", "0.54572517", "0.5457148", "0.54477173", "0.54364127", "0.54364127", "0.54364127", "0.54350483", "0.543028", "0.54296327", "0.5426727", "0.5414007", "0.5410806", "0.5406923", "0.5403324", "0.5401614" ]
0.6022624
19
Get current spell from spell API trough filter
public static Spell createSpellFromJsonString(String spellJsonString, String name) throws JSONException { JSONArray jsonArray = null; try { jsonArray = new JSONArray(spellJsonString); } catch (JSONException e) { e.printStackTrace(); } for (int i = 0; i < jsonArray.length(); i++) { try { JSONObject jsonObj = jsonArray.getJSONObject(i); if (jsonObj.getString("spell").equals(name)) { setSpell(jsonObj); break; } } catch (JSONException e) { e.printStackTrace(); } } return spell; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Spell getSpell(String spellType, Name spellName, Money price, Level level, Damage damage, Mana mana);", "SpellResponse spellQuery(SearchRequest request, Map<SearchParam, String> params);", "public final ItemScroll getSpell(int id) {\n\t\treturn spellmap.get(Integer.valueOf(id - Config.scrollStartIndex()));\n\t}", "public SpellList spells();", "@SneakyThrows\n public String get(String word) {\n String url = \"https://clients5.google.com/translate_a/t?client=dict-chrome-ex&sl=auto&tl=he&q=\"+word;\n this.response = getResponse(url);\n if(response.getSentences().size()>0) {\n return response.getSentences().get(0).getTrans();\n }\n return \"\";\n }", "public static Spell get(String spellName) {\n\t\treturn switch(spellName) {\n\t\tcase \"teleport self\" -> TeleportSelf.getInstance();\t\n\t\tcase \"dig\" -> Dig.getInstance();\n\t\tcase \"Summon lesser creature\" -> SummonLesserCreature.getInstance();\n\t\tdefault -> null; \n\t\t};\n\t}", "@Override\n public final ArrayList<Spell> getSpells(final float amp) {\n float newamp = amp;\n if (TerrainMap.getInstance().getTerrain(x, y) == TerrainTypes.Land) {\n newamp += SpellConstants.KNIGHTLANDBONUS;\n }\n return super.getSpells(newamp);\n }", "@Override\r\n\tpublic void onSpellHit(Spell spell) {\n\t\t\r\n\t}", "@Override\r\n\tpublic void onSpellHit(Spell spell) {\n\t\t\r\n\t}", "@Override\r\n\tpublic void onSpellHit(Spell spell) {\n\t\t\r\n\t}", "public SpellCheckResponseDto checkSpell(String requestString, int requestedsuggestion) {\n\t\tString collationWord = null;\n\t\tint statusCode = 0;\n\t\tSpellCheckResponseDto dto = new SpellCheckResponseDto(true);\n\n\t\tGetMethod method = new GetMethod(yahooServiceURL);\n\t\ttry {\n\t\t\tmethod.setQueryString(URIUtil.encodeQuery(requestString + \"?appid=\"+yahooServiceAppID));\n\t\t\tif(isProxySet){\n\t\t\t\tstatusCode = httpClient.executeMethod(hostconfig,method);\n\t\t\t} else {\n\t\t\t\tstatusCode = httpClient.executeMethod(method);\n\t\t\t}\n\n\t\t\tlogger.info(\"yahoo spell check status code: \" + statusCode);\n\t\t\tif(statusCode == 200) {\n\t\t\t\tInputStream rstream = null;\n\t\t\t\tBoundedBufferedReader br = null;\n\t\t\t\tString line;\n\t\t\t\ttry {\n\t\t\t\t\trstream = method.getResponseBodyAsStream();\n\t\t\t\t\tbr = new BoundedBufferedReader(new InputStreamReader(rstream));\n\t\t\t\t\twhile ((line = br.readLine()) != null) {\n\t\t\t\t\t\tline.trim();\n\t\t\t\t\t\tif(line.contains(\"suggestion\")){\n\t\t\t\t\t\t\tcollationWord = line.substring(line.indexOf(\">\") + 1, line.indexOf(\"</\"));\n\t\t\t\t\t\t\tdto.setCorrect(false);\n\t\t\t\t\t\t\tdto.getSuggestions().add(collationWord);\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tlogger.info(\"yahoo spell check: collation word : \" + collationWord);\n\t\t\t\t} \n\t\t\t\tcatch(Exception e)\n\t\t\t\t{\n\t\t\t\t\te.printStackTrace();\n\t\t\t\t}\n\t\t\t\tfinally {\n\t\t\t\t\tif(br != null) {\n\t\t\t\t\t\tbr.close();\n\t\t\t\t\t}\n\t\t\t\t\tif(rstream != null) {\n\t\t\t\t\t\trstream.close();\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t} \n\t\t} catch (URIException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (HttpException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t} catch (IOException e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn dto;\n\t}", "@Override\r\n\tpublic void onSpellHit(Spell spell) {\n\t\tif (spell.getName().contains(\"Antlitz der Göttin\")){\r\n\t\t\tcaster.setFlying(false);\r\n\t\t\tcaster.setAllowFlight(false);\r\n\t\t}\r\n\t}", "Recipe getRecipe(CharSequence query);", "public String spellcheck(String word) {\n // Check if the world is already in lcDictionary.\n String lcdictionaryLookup = lcDictionary.get(word.toLowerCase());\n if(lcdictionaryLookup != null) {\n return lcdictionaryLookup;\n }\n String reducedWord = reducedWord(word);\n String rwdictionaryLookup = rwDictionary.get(reducedWord);\n if(rwdictionaryLookup != null) {\n return rwdictionaryLookup;\n }\n return \"NO SUGGESTION\";\n }", "public Word getWord(int id);", "public int getSpellVamp() {\n\t\t\n\t\treturn spellVamp;\n\t}", "@Override\n\t\t\tpublic Spell pickSpell(Spell[] spells, EntityWisp wisp) {\n\t\t\t\treturn getSpellToUse();\n\t\t\t}", "java.lang.String getWord();", "public default void doEffectStart(SpellData data, World world, Side onSide){ }", "public String getSpelling() {\n\t\treturn this.spelling;\n\t}", "public void spell(SpellRequest parsedRequest, GameServer gServer) {\n gameServer = gServer;\n Log.i(TAG, \"Handle spell \" + parsedRequest.toString());\n Hero hero = GameUtil.getHeroById(parsedRequest.getHeroId(), gameServer.getHeroes());\n switch (parsedRequest.getSpell_id()) {\n case 8:\n Log.i(TAG, \"Warrior used taunt!\");\n warriorTaunt((Warrior) hero, parsedRequest);\n break;\n case 7:\n Log.i(TAG, \"Warrior used cleave!\");\n warriorCleave((Warrior) hero, parsedRequest);\n break;\n case 1:\n Log.i(TAG, \"Warrior used Charge!\");\n warriorCharge((Warrior) hero, parsedRequest);\n break;\n case 2:\n Log.i(TAG, \"Priest used Heal!\");\n priestHeal((Priest) hero, parsedRequest);\n break;\n case 3:\n Log.i(TAG, \"Priest used Smite!\");\n priestSmite((Priest) hero, parsedRequest);\n break;\n case 6:\n Log.i(TAG, \"Priest used Shield!\");\n priestShield((Priest) hero, parsedRequest);\n break;\n case 5:\n Log.i(TAG, \"Priest used Heal over time!\");\n priesHealOverTime((Priest) hero, parsedRequest);\n break;\n case 26:\n Log.i(TAG, \"Warlock used drain life!\");\n warlockDrain((Warlock) hero, parsedRequest);\n break;\n case 27:\n Log.i(TAG, \"Warlock used haemorrhage!\");\n warlockHaemorrhage((Warlock) hero, parsedRequest);\n break;\n case 28:\n Log.i(TAG, \"Warlock used restore!\");\n warlockRestore((Warlock) hero, parsedRequest);\n break;\n case 29:\n Log.i(TAG, \"Warlock used restore!\");\n warlockBloodBolt((Warlock) hero, parsedRequest);\n break;\n default:\n Log.i(TAG, \"Did not find spell with id: \" + parsedRequest.getSpell_id());\n break;\n }\n gServer.sendGameStatus();\n }", "WordBean getWord(String word);", "public String getSpelling() {\n\t\t\treturn this.spelling;\n\t\t}", "public default int getCastingTime(){ return Spell.STANDARD_ACTION; }", "public String getLexEntry(String word)\n {\n boolean found = false;\n String buff = \"\";\n String rtn = \"\";\n\n lastCount = 0.0;\n if(word.length() > 0)\n {\n buff = compactNumbers(word);\n rtn = searchLexDb(buff, true);\n if(rtn.length() > 0)\n found = true;\n\n else // try the lowercase version\n {\n buff = buff.toLowerCase();\n rtn = searchLexDb(buff, true);\n if(rtn.length() > 0)\n found = true;\n } // else\n } // fi\n\n // If not found, get the search string corresponding to the word.\n\n if(!found)\n {\n buff = searchString(word);\n\n while(!found && (buff.length() > 0))\n {\n rtn = searchLexDb(buff, false);\n if(rtn.length() > 0)\n found = true;\n else\n buff = buff.substring(1);\n } // while\n } // fi\n\n if(!found)\n System.out.println(\"word: #\" + word + \"# lex entry not found\");\n\n return(rtn.toString());\n }", "public interface IWord2Spell {\r\n String word2spell();\r\n}", "public String getEngWordFromThaiWord(String thaiWord) {\n Cursor cursor = mDatabase.query(\n TABLE_NAME,\n new String[]{COL_ENG_WORD},\n COL_THAI_WORD + \"=?\",\n new String[]{thaiWord},\n null,\n null,\n null\n );\n if (cursor.getCount() > 0) {\n cursor.moveToFirst();\n return cursor.getString(cursor.getColumnIndex(COL_ENG_WORD));\n } else {\n return thaiWord;\n }\n }", "@Override\n protected FilterResults performFiltering(CharSequence arg0) {\n String[] tmp = API.it().getKeywords(arg0.toString());\n FilterResults results = new FilterResults();\n results.values = tmp;\n results.count = tmp.length;\n return results;\n }", "public String getCorrectionWord(String misspell);", "public Cursor getWord(String word) {\n\n\t\tString query = String.format(_select, getDate()) +\n\t\t\t\t\t\t\" WHERE \" + DBConstants.WordTable.WORD_KEY + \" = '\" + word + \"'\";\n\t\t\n\t\treturn _db.rawQuery(query, null);\t\t\n }", "public void getWord() {\n\t\t\n\t}", "private void initialiseWordsToSpell(){\n\t\t//normal quiz\n\t\tif(quiz_type==PanelID.Quiz){\n\t\t\twords_to_spell = parent_frame.getPreQuizHandler().getWordsForSpellingQuiz(parent_frame.getDataHandler().getNumWordsInQuiz(), PanelID.Quiz);\n\t\t} else { //review quiz\n\t\t\twords_to_spell = parent_frame.getPreQuizHandler().getWordsForSpellingQuiz(parent_frame.getDataHandler().getNumWordsInQuiz(), PanelID.Review);\n\t\t}\t\n\t}", "private WordRecord lookUp(String word)\n {\n int contains = 0;\n boolean check = false;\n //loops through concordance\n for(int i = 0; i < this.concordance.size();i++)\n {\n //checks to see if the words are equal\n if(word.equalsIgnoreCase(this.concordance.get(i).getWord()))\n {\n //gets location of what position the word is true\n contains = i;\n check = true;\n }\n \n }\n //checks to see if it was found in concordance\n if(check)\n return this.concordance.get(contains);\n \n return null;\n }", "private Word askForWord(Language lastLanguage) throws LanguageException {\n Language language = askForLanguage();\r\n if(language == null || language.equals(lastLanguage)) {\r\n throw new LanguageException();\r\n }\r\n // Step 2 : Name of the word\r\n String name = askForLine(\"Name of the word : \");\r\n Word searchedWord = czech.searchWord(language, name);\r\n if(searchedWord != null) {\r\n System.out.println(\"Word \" + name + \" found !\");\r\n return searchedWord;\r\n }\r\n System.out.println(\"Word \" + name + \" not found.\");\r\n // Step 3 : Gender/Phonetic of the word\r\n String gender = askForLine(\"\\tGender of the word : \");\r\n String phonetic = askForLine(\"\\tPhonetic of the word : \");\r\n // Last step : Creation of the word\r\n Word word = new Word(language, name, gender, phonetic);\r\n int id = czech.getListWords(language).get(-1).getId() + 1;\r\n word.setId(id);\r\n czech.getListWords(language).put(-1, word);\r\n return word;\r\n }", "private static String getPhraseInput() {\n\t\treturn getQuery(\"Query Phrase\");\n\t}", "private void castSpellByAI() {\n\t\tboolean spellIsNotActivated = true;\n\t\tboolean[] spellsFlags = new boolean[3];\n\t\tChampion AI = currentTask.getCurrentChamp();\n\t\tArrayList<Spell> spells = ((Wizard)AI).getSpells();\n\t\twhile(spellIsNotActivated){\n\t\t\t\n\t\t\tint randomAction = (int) (Math.random()*2);\n\t\t\tSpell spell = null;\n\t\t\t\n\t\t\tswitch(randomAction){\n\t\t\tcase 0: if(spellsFlags[0]==false) {spell = spells.get(0); spellsFlags[0]=true; break;}\n\t\t\tcase 1:\tif(spellsFlags[1]==false) {spell = spells.get(1); spellsFlags[1]=true; break;}\n\t\t\tdefault: if(spellsFlags[2]==false) {spell = spells.get(2); spellsFlags[2] =true;}\n\t\t\t}\n\t\t\t\n\t\t\tif(spell instanceof HealingSpell){\n\t\t\t\tcastHealingSpell(spell);\n\t\t\t}else if(spell instanceof DamagingSpell){\n\t\t\t\tDirection direction;\n\t\t\t\tint randomDirection = (int) (Math.random()*3);\n\t\t\t\tswitch(randomDirection){\n\t\t\t\tcase 0: direction = Direction.BACKWARD;\n\t\t\t\tcase 1: direction = Direction.FORWARD;\n\t\t\t\tcase 2: direction = Direction.LEFT;\n\t\t\t\tdefault: direction = Direction.RIGHT;\n\t\t\t\t}\n\t\t\t\tspellInAction = spell;\n\t\t\t\tdirectionsInAction = new ArrayList<Direction>();\n\t\t\t\tdirectionsInAction.add(direction);\n\t\t\t\tcastDamagingSpell();\n\t\t\t}else if(spell instanceof RelocatingSpell){\n\t\t\t\tDirection direction1;\n\t\t\t\tint randomDirection1 = (int) (Math.random()*3);\n\t\t\t\tswitch(randomDirection1){\n\t\t\t\tcase 0: direction1 = Direction.BACKWARD;\n\t\t\t\tcase 1: direction1 = Direction.FORWARD;\n\t\t\t\tcase 2: direction1 = Direction.LEFT;\n\t\t\t\tdefault: direction1 = Direction.RIGHT;\n\t\t\t\t}\n\t\t\t\tDirection direction2;\n\t\t\t\tint randomDirection2 = (int) (Math.random()*3);\n\t\t\t\tswitch(randomDirection2){\n\t\t\t\tcase 0: direction2 = Direction.BACKWARD;\n\t\t\t\tcase 1: direction2 = Direction.FORWARD;\n\t\t\t\tcase 2: direction2 = Direction.LEFT;\n\t\t\t\tdefault: direction2 = Direction.RIGHT;\n\t\t\t\t}\n\t\t\t\tspellInAction = spell;\n\t\t\t\tdirectionsInAction = new ArrayList<Direction>();\n\t\t\t\tdirectionsInAction.add(direction1);\n\t\t\t\tdirectionsInAction.add(direction2);\n\t\t\t\t\n\t\t\t\tint randomRange = (int) (Math.random()*((RelocatingSpell)spell).getRange()) + 1;\n\t\t\t\tcastRelocatingSpell(randomRange);\n\t\t\t\t\n\t\t\t}else{\n\t\t\t\tspellIsNotActivated = false;\n\t\t\t}\n\t\t\tif(AI != currentTask.getCurrentChamp()){\n\t\t\t\tspellIsNotActivated = false;\n\t\t\t}\n\t\t}\n\n\t\t\n\t\t\n\t}", "public void setSelectedSpell(Spell spell) {\n selectedSpell = spell;\n }", "private void listen_meaning_word() {\n\t\tif(this.dwd!=null)\n\t\t{\n\t\t\tString meaning_word=\"\";\n\t\t\tif(isHindi)\n\t\t\t{\n\t\t\t\tmeaning_word=dwd.eng_word;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tmeaning_word=dwd.hin_word;\n\t\t\t}\n\t\t\tif(isHindi)\n\t\t\t{\n\t\t\t\tif(this.main_word!=\"\")\n\t\t\t\t{\n\t\t\t\t\tif(mCallBack==null)\n\t\t\t\t\t{\n\t\t\t\t\t\tmCallBack=(OnWordSelectedFromSearchSuccess) getActivity();\n\t\t\t\t\t}\n\t\t\t\t\tmCallBack.onWordSpeak(meaning_word);\n\t\t\t\t}\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\tDictCommon.listen_in_hindi(meaning_word);\n\t\t\t}\n\t\t}\n\t}", "private void addSpell(Bundle bundle) {\n Toast.makeText(getContext(), \"Not yet implemented\", Toast.LENGTH_SHORT).show();\n }", "public WordInfo searchWord(String word) {\n\t\tSystem.out.println(\"Dic:SearchWord: \"+word);\n\n\t\tDocument doc;\n\t\ttry {\n\t\t\tdoc = Jsoup.connect(\"https://dictionary.cambridge.org/dictionary/english-vietnamese/\" + word).get();\n\t\t} catch(Exception e) {\n\t\t\te.printStackTrace();\n\t\t\treturn null;\n\t\t}\n\n\t\tElements elements = doc.select(\".dpos-h.di-head.normal-entry\");\n\t\tif (elements.isEmpty()) {\n\t\t\tSystem.out.println(\" not found\");\n\t\t\treturn null;\n\t\t}\n\n\t\tWordInfo wordInfo = new WordInfo(word);\n\n\t\t// Word\n\t\telements = doc.select(\".tw-bw.dhw.dpos-h_hw.di-title\");\n\n\t\tif (elements.size() == 0) {\n\t\t\tSystem.out.println(\" word not found in doc!\");\n\t\t\treturn null;\n\t\t}\n\n\t\twordInfo.setWordDictionary(elements.get(0).html());\n\n\t\t// Type\n\t\telements = doc.select(\".pos.dpos\");\n\n\t\tif(elements.size() > 0) {\n\t\t\twordInfo.setType(WordInfo.getTypeShort(elements.get(0).html()));\n//\t\t\tif (wordInfo.getTypeShort().equals(\"\"))\n//\t\t\t\tSystem.out.println(\" typemis: \"+wordInfo.getType());\n\t\t}\n\n\t\t// Pronoun\n\t\telements = doc.select(\".ipa.dipa\");\n\n\t\tif (elements.size() > 0)\n\t\t\twordInfo.setAPI(\"/\"+elements.get(0).html()+\"/\");\n\n\t\t// Trans\n\t\telements = doc.select(\".trans.dtrans\");\n\n\t\tif (elements.size() > 0)\n\t\t\twordInfo.setTrans(elements.get(0).html());\n\n\t\tSystem.out.println(\" found\");\n\t\treturn wordInfo;\n\t}", "public String getTerm(){\n return this.term;\n }", "public abstract List<Technique> findTechniqueByName(String technique);", "public Player getPlayer(Term term, User user);", "public String getThaiWordFromEngWord(String englishWord) {\n Cursor cursor = mDatabase.query(\n TABLE_NAME,\n new String[]{COL_THAI_WORD},\n COL_ENG_WORD + \"=?\",\n new String[]{englishWord},\n null,\n null,\n null\n );\n if (cursor.getCount() > 0) {\n cursor.moveToFirst();\n return cursor.getString(cursor.getColumnIndex(COL_THAI_WORD));\n } else {\n return englishWord;\n }\n }", "public String getWord()\n\t{\n\t\treturn word.get(matcher());\n\t}", "public void setSpellQuery(String query) {\n\t\tspellQuery.setText(query);\n\t}", "@Override\n protected void query(CompletionResultSet completionRS, Document doc, int caretOffset) {\n // First, we retrieve the filters defined for the hAtom microformat completion\n String strFilter = Filter.EMPRTY_STRING;\n Filter filter = Filter.getFilter();\n \n try {\n StyledDocument styledDoc = (StyledDocument) doc; \n // Get the filter's text based on actual carte position.\n strFilter = filter.getText(styledDoc, caretOffset);\n \n } catch (Exception ex) {\n ex.printStackTrace();\n // if an error occurs, an empty filter is set, so that the completion popup \n // will be filled with all the hAtom keywords.\n strFilter = Filter.EMPRTY_STRING;\n }\n\n // Lista completa dei tag/parole chiave hAtom\n List<String> hatomTags = TagCache.getCache().getTagList();\n\n // Gets the hAtom keywords that match the given filter value.\n for (String tag : hatomTags) {\n boolean startWithFilter = tag.startsWith(strFilter); \n if (!tag.equals(Filter.EMPRTY_STRING) && startWithFilter) {\n completionRS.addItem(new HatomCompletionItem(tag, filter.getFilterOffset(), caretOffset));\n }\n }\n\n // This is required by the Netbeans API docs.\n // After finish() is invoked, no further modifications to the result set are allowed.\n completionRS.finish();\n\n }", "@Override\n public SpellCheckState getState() {\n return (SpellCheckState) super.getState();\n }", "private void laadSpellen() {\r\n this.spellen = this.dc.geefOpgeslagenSpellen();\r\n int index = 0;\r\n String res = String.format(\"%25s %20s\", r.getString(\"spelNaam\"), r.getString(\"moeilijkheidsGraad\"));\r\n for (String[] rij : spellen) {\r\n index++;\r\n res += String.format(\"%n%d) %20s\", index, rij[0]);\r\n switch (rij[1]) {\r\n case \"1\":\r\n res += String.format(\"%20s\", r.getString(\"makkelijk\"));\r\n break;\r\n case \"2\":\r\n res += String.format(\"%20s\", r.getString(\"gemiddeld\"));\r\n break;\r\n case \"3\":\r\n res += String.format(\"%20s\", r.getString(\"moeilijk\"));\r\n break;\r\n }\r\n \r\n }\r\n System.out.printf(res);\r\n }", "@Override\n public List<DefinitionDTO> findWordsByWord(String query) {\n List<Word> words = wordRepository.findBySearchString(query);\n return DTOMapper.mapWordListToDefinitionDTOList(words);\n }", "private void searchWord()\n {\n String inputWord = searchField.getText();\n \n if(inputWord.isEmpty())\n queryResult = null;\n \n else\n {\n char firstLetter = inputWord.toUpperCase().charAt(0);\n \n for(int i = 0 ; i < lexiNodeTrees.size() ; i++)\n {\n if(lexiNodeTrees.get(i).getCurrentCharacter() == firstLetter)\n {\n queryResult = lexiNodeTrees.get(i).searchWord(inputWord, false);\n i = lexiNodeTrees.size(); // escape the loop\n }\n }\n }\n \n // update the list on the GUI\n if(queryResult != null)\n {\n ArrayList<String> words = new ArrayList<>();\n for(WordDefinition word : queryResult)\n {\n words.add(word.getWord());\n }\n \n // sort the list of words alphabetically \n Collections.sort(words);\n \n // display the list of wordsin the UI\n DefaultListModel model = new DefaultListModel();\n for(String word : words)\n {\n model.addElement(word);\n }\n\n this.getSearchSuggestionList().setModel(model);\n }\n \n else\n this.getSearchSuggestionList().setModel( new DefaultListModel() );\n }", "public String getWord(){\n return this.word;\n }", "private String wordToFind() {\n\t\t\n\t\t//It actually just gets the incomplete version of the word, with underscores.\n\t\t//By the point this method is called, the server will have created a thread for\n\t\t//this client and generated a random word for this client to aim for. \n\t\t//The underscore variant will be just as long as the real word, so it can be used\n\t\t//for array lengths and, since it'll be all underscores, even if a hacker went to\n\t\t//print out the value of temp, they wouldn't get anywhere.\n\t\tout.println(\"GetWord\");\n\t\tString temp = null;\n\t\twhile(true) {\n\t\t\ttry {\n\t\t\t\ttemp = in.readLine();\n\t\t\t\tif(temp!=null) {\n\t\t\t\t\tcurrentWordLabel = new Label(temp);\n\t\t\t\t\treturn temp;\n\t\t\t\t}\n\t\t\t}catch(IOException ioe) {\n\t\t\t}\n\t\t}\n\t}", "public void spell(Player player, Spell spell)\n {\n \n if(isUsingSpell(player))\n {\n cancelSpell(player);\n }\n \n spells.put(player, spell);\n player.addPotionEffect(new PotionEffect(PotionEffectType.SLOW, CustomItemsAPI.secondsToTicks(2), 2));\n player.getWorld().playSound(player.getLocation(), Sound.ENTITY_ZOMBIE_VILLAGER_CONVERTED, 0.4f, 0.4f);\n }", "private void listen_word() {\n\t\tif(this.dwd!=null && this.main_word!=null)\n\t\t{\n\t\t\tif(this.main_word!=\"\")\n\t\t\t{\n\t\t\t\tif(isHindi)\n\t\t\t\t{\n\t\t\t\t\tDictCommon.listen_in_hindi(this.main_word);\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tif(mCallBack==null)\n\t\t\t\t\t{\n\t\t\t\t\t\tmCallBack=(OnWordSelectedFromSearchSuccess) getActivity();\n\t\t\t\t\t}\n\t\t\t\t\tmCallBack.onWordSpeak(this.main_word);\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t}", "@Override\n public String getWord(){\n return word;\n }", "public abstract AutoCompleteDictionary getDictionary(SearchCategory categoryToSearch);", "public static void main(String[] args) {\n System.out.println(canSpell2(\"hapseadoost\",\"ostehaps\"));\n }", "public static CommandType getWord(String word){\r\n\t\treturn dictionary.get(word);\r\n\t}", "public SpellCheckerManager getSpellCheckerManager() {\n return spellCheckerManager;\n }", "public Word getWord() {\n return word;\n }", "private void useSpell(Room currentRoom, Player player, String spell) throws IllegalArgumentException\n\t{\n\t\t//Check if the spell is an offensive spell\n\t\tif (player.getFaction().getLandSpells().contains(Spell.valueOf(spell)))\n\t\t{\n\t\t\tSpell s = Spell.valueOf(spell);\n\t\t\tplayer.useLandSpell(s, currentRoom);\n\t\t}\n\t\t//Check if the spell is a land spell\n\t\telse if (player.getFaction().getOffensiveSpells().contains(Spell.valueOf(spell)))\n\t\t{\n\t\t\tSpell s = Spell.valueOf(spell);\n\t\t\tif (currentRoom instanceof MonsterRoom)\n\t\t\t{\n\t\t\t\tEntityLiving e = ((MonsterRoom) currentRoom).getMonster();\n\t\t\t\tplayer.useOffensiveSpell(s, e);\n\t\t\t\tif (!e.isDead())\n\t\t\t\t\te.attack(player);\n\t\t\t}\n\t\t\telse if (currentRoom instanceof BossRoom)\n\t\t\t{\n\t\t\t\tEntityLiving e = ((BossRoom) currentRoom).getBoss();\n\t\t\t\tplayer.useOffensiveSpell(s, e);\n\t\t\t\tif (!e.isDead())\n\t\t\t\t\te.attack(player);\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tthrow new IllegalArgumentException();\n\t\t}\n\t}", "private static void addSpell(Thing t) {\r\n \t\tString name=t.getString(\"Name\");\r\n \t\tspellNames.add(name);\r\n \t\t\r\n \t\tGame.assertTrue(t.getFlag(\"IsSpell\"));\r\n \r\n \t\tint level=t.getStat(\"Level\");\r\n \t\tGame.assertTrue(level>0);\r\n \t\tt.set(\"LevelMin\",level);\r\n \r\n \t\tint skillMin=(t.getStat(\"SpellCost\"))*3;\r\n \t\tt.set(\"SkillMin\",skillMin);\r\n \t\t\r\n \t\tt.set(\"Image\",t.getStat(\"BoltImage\"));\r\n \t\tt.set(\"ImageSource\",\"Effects\");\r\n \t\t\r\n \t\t//int power=(int)(6*Math.pow(spellPowerMultiplier,level));\r\n \t\t//Game.assertTrue(power>0);\r\n \t\t//t.set(\"Power\",power);\r\n \t\tLib.add(t);\r\n \t}", "public String getPortalSpell(Location location, Entity entity) {\n MagicBlock magicBlock = getConnectedBlock(location);\n String magicBlockSpell = magicBlock != null ? magicBlock.getPortalSpell() : null;\n if (magicBlockSpell != null) {\n return magicBlockSpell;\n }\n\n // Fall back to regions\n Player player = entity instanceof Player ? (Player)entity : null;\n return worldGuardManager.getPortalSpell(player, location);\n }", "List<T> getWord();", "public String getWord() {\n return this.word;\n }", "public String filter(final VariantContext ctx);", "public DictionaryData lookup(String word) {\r\n\r\n return dictionaryMap.get(word.toUpperCase());\r\n }", "public static void main(String[] args) {\n String filePath = \"/usr/share/dict/words\";\n SpellChecker sc = new SpellChecker(filePath);\n String line;\n System.out.print(\"> \");\n BufferedReader input = new BufferedReader(new InputStreamReader(System.in));\n try {\n while((line = input.readLine())!= null) {\n String correctSpelling = sc.spellcheck(line);\n System.out.println(correctSpelling);\n System.out.print(\"> \");\n }\n System.out.println();\n } catch (IOException e){\n e.printStackTrace();\n }\n }", "public Boolean lookupAWord(String target) {\n ArrayList<Word> fullDictionary = dictionaryManagement.getDictionary().getWords();\n int result = dictionaryManagement.lookupWord(target);\n if (result == -1) {\n System.out.println(\"This word is dose not exsit!\");\n return false;\n } else {\n System.out.println(\"Result: \");\n System.out.println(\"\\tTarget: \" + target);\n System.out.println(\"\\tExplain: \" + fullDictionary.get(result).getWordExplain());\n return true;\n }\n }", "private static void doEffect(Thing caster, Thing spell, Thing target) {\r\n \t\tint magicSkill=Spell.calcMagicSkill(caster,spell);\r\n \t\tint magicDefence=Spell.calcAntiMagic(target);\r\n \t\tint magicPower=Spell.calcMagicPower(caster,spell);\r\n \t\t\r\n \t\t// work out whether spell is effective\r\n \t\tboolean effective=true;\r\n \t\tboolean visible=target.isVisible(Game.hero());\r\n \t\tif ((magicDefence>0)&&spell.getStat(\"SpellUsage\")==Spell.SPELL_OFFENCE) {\r\n \t\t\tmagicSkill+=magicPower/5;\r\n \t\t\tGame.warn(\"Magic test: \"+magicSkill+\" vs. \"+magicDefence);\r\n \t\t\t\r\n \t\t\teffective=magicSkill>=(magicDefence*RPG.luckRandom(caster,target));\r\n \t\t}\r\n \t\t\r\n \t\tif ((caster!=null)&&target.getFlag(\"IsBeing\")&&(spell.getStat(\"SpellUsage\")==Spell.SPELL_OFFENCE)) {\r\n \t\t\tAI.notifyAttack(target,caster);\r\n \t\t}\r\n \t\t\r\n \t\tString hitname=spell.getString(\"HitName\");\r\n \t\tif (effective){\r\n \t\t\tif (hitname!=null) target.message(\"You are hit by the \"+hitname);\r\n \t\t\tEvent e=new Event(\"Effect\");\r\n \t\t\te.set(\"Strength\",magicPower);\r\n \t\t\te.set(\"Caster\",caster);\r\n \t\t\te.set(\"Target\",target);\r\n \t\t\tspell.handle(e);\r\n \t\t} else {\r\n \t\t\tif (visible) Game.message(target.getTheName()+\" \"+target.verb(\"resist\")+\" the \"+hitname);\r\n \t\t}\r\n \t}", "@GET\n @Path(\"/filter\")\n @Produces(\"text/plain\")\n public String getFilterWordList() throws JsonProcessingException {\n ObjectMapper mapper = new ObjectMapper();\n return mapper.writeValueAsString(FilterImpl.getList());\n }", "@java.lang.Override\n public com.clarifai.grpc.api.Search getSearch() {\n if (inputSourceCase_ == 10) {\n return (com.clarifai.grpc.api.Search) inputSource_;\n }\n return com.clarifai.grpc.api.Search.getDefaultInstance();\n }", "@Override\r\n\tprotected void getIntentWord() {\n\t\tsuper.getIntentWord();\r\n\t}", "public Skills getChosenSkill();", "public void spellLevelUp() {\n \n }", "public String getWord() {\n return word;\n }", "public Icon getIcon(String spellName);", "@GET(\"w/api.php?action=opensearch&format=json&suggest&redirects=resolve\")\n Call<JsonElement> getSuggestionsFromSearch(@Query(\"search\") String search);", "public String getCurrent_word(){\n\t\treturn current_word;\n\t}", "@Nullable\r\n public static JSONArray retrieveSuggestions(final Context context, String word)\r\n {\r\n JSONArray content;\r\n\r\n try\r\n {\r\n RequestFuture<JSONArray> future = RequestFuture.newFuture();\r\n\r\n SharedPreferencesManager sharedPreferencesManager = new SharedPreferencesManager(context);\r\n\r\n User user = sharedPreferencesManager.retrieveUser();\r\n\r\n final String fixedURL = Utils.fixUrl(\r\n Properties.SERVER_URL + \":\" + Properties.SERVER_SPRING_PORT + \"/suggest/\" + user.getId() + \"/\" + word);\r\n\r\n Log.d(Properties.TAG, \"[REST_CLIENT_SINGLETON] Conectando con: \" + fixedURL + \" para traer las sugerencias\");\r\n\r\n // Creamos una peticion\r\n final JsonArrayRequest jsonObjReq = new JsonArrayRequest(Request.Method.GET\r\n , fixedURL\r\n , null\r\n , future\r\n , future);\r\n\r\n // La mandamos a la cola de peticiones\r\n VolleySingleton.getInstance(context).addToRequestQueue(jsonObjReq);\r\n Log.d(Properties.TAG, \"[REST_CLIENT_SINGLETON] Petición creada y recibida\");\r\n\r\n try\r\n {\r\n content = future.get(20, TimeUnit.SECONDS);\r\n\r\n } catch (InterruptedException e) {\r\n ExceptionPrinter.printException(\"REST_CLIENT_SINGLETON\", e);\r\n\r\n return null;\r\n }\r\n\r\n // Si content es vacio, es que han fallado todas las conexiones.\r\n if (content == null)\r\n {\r\n Log.e(Properties.TAG, \"[REST_CLIENT_SINGLETON] No se ha recibido nada\");\r\n\r\n return null;\r\n }\r\n\r\n } catch (Exception e) {\r\n ExceptionPrinter.printException(\"REST_CLIENT_SINGLETON\", e);\r\n\r\n return null;\r\n }\r\n\r\n return content;\r\n }", "entities.Torrent.SearchResponse getSearchResponse();", "private ArrayList<String> findChampions() {\n\t\tString searchContents = search.getText();\n\t\tArrayList<String> result = new ArrayList<String>();\n\t\tfor (String c : CHAMPIONLIST) {\n\t\t\tif (c.toLowerCase().contains(searchContents.toLowerCase())) {\n\t\t\t\tresult.add(c);\n\t\t\t}\n\t\t}\n\t\treturn result;\n\t}", "public String getTerm() {\n return term;\n }", "public static void main(String[] args) {\n System.out.println(canSpell2(\"hapsadoost\", \"ostehaaaps\"));\n }", "public String getWord(){\r\n\t\treturn word;\r\n\t}", "private static void addItemSpell(Thing t) {\r\n \t\taddSpell(t);\r\n \t}", "public interface DictionaryCorrectior {\n\n\t/**\n\t * get correction word that have the most possibility from the misspelled text\n\t * @author liyuan\n\t * \n\t */\n\tpublic String getCorrectionWord(String misspell);\n\t\n\t\n\t\n\t/**\n\t * get a list of correction words from the misspelled text\n\t * @author liyuan\n\t * \n\t */\n\tpublic String[] getCorrectionList(String misspell);\n}", "public String getWord(){\r\n\t\t return word;\r\n\t }", "private String getSentence(Context context) {\n HttpRequest httpRequest = HttpRequest.newBuilder()\n .GET()\n .uri(URI.create(ALBUM_SERVICE_URL + RANDOM.nextInt(100)))\n .setHeader(\"User-Agent\", \"Java 11 HttpClient Bot\")\n .timeout(Duration.ofMillis(1200))\n .build();\n\n try {\n HttpResponse<String> response = HTTP_CLIENT.send(httpRequest, HttpResponse.BodyHandlers.ofString());\n\n if (response.statusCode() == HTTP_OK) {\n\n AlbumJson albumJson = ALBUM_JSON_PARSER.parse(response.body());\n return \", your sentence of the day: \" + albumJson.getTitle();\n }\n } catch (IOException | InterruptedException e) {\n final LambdaLogger logger = context.getLogger();\n logger.log(\"Error: \" + Arrays.toString(e.getStackTrace()));\n }\n return \"\";\n }", "public void display(Spell spell) {\n\n\n //we actualize the selected metamagic\n currentSpell = spell;\n\n name.setText(spell.getName());\n level.setText(Integer.toString(spell.getLevel()));\n description.setText(spell.getDescription());\n school.setText(spell.getSchool().toString());\n descriptors.setText(spell.getDescriptorList().toString());\n range.setText(spell.getRange());\n area.setText(spell.getArea());\n duration.setText(spell.getDuration());\n castingTime.setText(spell.getCastingTime());\n link.setText(spell.getLink());\n\n }", "Skill getSkill(String name);", "entities.Torrent.LocalSearchResponse getLocalSearchResponse();", "private List<SearchWord> getSearchWords(Long lastUpdateTime) {\n return new ArrayList<>();\n }", "public Resource getWordsLocation() {\n return wordsLocation;\n }", "public int parseSpellChoice(List<Spell> list) {\n\t\tSystem.out.println(\"Which Spell would you like to cast?\");\n\t\tprintSpellList(list);\n\t\treturn parseChoice(list,1);\n\t\t\n\t\t\n\t}", "public Spell() {}", "public Cursor getWords() \n\t{\n\t\tString query = String.format(_select, getDate()) +\n\t\t\t\t\t\t_havingDataContraint +\n\t\t\t\t\t\t\" ORDER BY \" + DBConstants.WordTable.WORD_KEY;\n\t\t\n\t\treturn _db.rawQuery(query, null);\t\n }", "public String getWord(){\n\t\treturn word;\n\t}", "public Sword getCurrentSword() {\n return currentSword;\n\t}" ]
[ "0.64552635", "0.61346465", "0.604456", "0.5917846", "0.5890714", "0.5888592", "0.56160355", "0.5530465", "0.5530465", "0.5530465", "0.5495981", "0.5484183", "0.54780406", "0.547116", "0.5462718", "0.5436712", "0.5436442", "0.5432829", "0.5419235", "0.5385231", "0.53577876", "0.53193563", "0.5302286", "0.5246056", "0.52279425", "0.52260995", "0.52073497", "0.51988876", "0.5188371", "0.5152111", "0.5143873", "0.51077116", "0.5101536", "0.50997925", "0.5092776", "0.507121", "0.5052081", "0.5047243", "0.5036902", "0.50368255", "0.50359356", "0.50319725", "0.50220084", "0.49921027", "0.49897796", "0.49838948", "0.4975066", "0.4966804", "0.49554643", "0.49229434", "0.4898226", "0.48962805", "0.48904505", "0.48832974", "0.48697728", "0.48630992", "0.48608592", "0.48604092", "0.48569688", "0.48533708", "0.48493287", "0.48458898", "0.48454338", "0.4831545", "0.4822105", "0.4819989", "0.48166296", "0.48126966", "0.4805515", "0.47820574", "0.47801524", "0.4779507", "0.47736138", "0.47722837", "0.4769363", "0.47689512", "0.47628877", "0.47575384", "0.47572488", "0.47539476", "0.4753705", "0.4748855", "0.47384727", "0.47381946", "0.4737901", "0.47361374", "0.4734348", "0.4733707", "0.47308952", "0.47156575", "0.47150612", "0.4712341", "0.47051167", "0.47018823", "0.47011805", "0.46958163", "0.4694671", "0.46922606", "0.46917203", "0.4689054" ]
0.50747114
35
TODO Autogenerated method stub
@Override public void add() { person.addRelationship("Friend", friend); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n public void perish() {\n \n }", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "@Override\n\tpublic void anular() {\n\n\t}", "@Override\n\tprotected void getExras() {\n\n\t}", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "@Override\n\tprotected void interr() {\n\t}", "@Override\n\tpublic void emprestimo() {\n\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "@Override\n protected void getExras() {\n }", "@Override\r\n\tpublic void publierEnchere() {\n\t\t\r\n\t}", "@Override\n\tpublic void nefesAl() {\n\n\t}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "@Override\n public void func_104112_b() {\n \n }", "@Override\n\tprotected void initdata() {\n\n\t}", "@Override\n\tpublic void nghe() {\n\n\t}", "@Override\n public void function()\n {\n }", "@Override\n public void function()\n {\n }", "public final void mo51373a() {\n }", "@Override\r\n\tpublic void stehReagieren() {\r\n\t\t//\r\n\t}", "@Override\n public void inizializza() {\n\n super.inizializza();\n }", "@Override\n\tprotected void initData() {\n\t\t\n\t}", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "@Override\r\n\tprotected void InitData() {\n\t\t\r\n\t}", "public void designBasement() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "public void gored() {\n\t\t\n\t}", "@Override\r\n\tprotected void initData() {\n\r\n\t}", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n protected void initialize() {\n\n \n }", "public void mo38117a() {\n }", "@Override\n\tprotected void getData() {\n\t\t\n\t}", "Constructor() {\r\n\t\t \r\n\t }", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\n\tpublic void one() {\n\t\t\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "private stendhal() {\n\t}", "@Override\n\tprotected void update() {\n\t\t\n\t}", "@Override\n\t\t\tpublic void ic() {\n\t\t\t\t\n\t\t\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n public void init() {\n\n }", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\n\tpublic void debite() {\n\t\t\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "public contrustor(){\r\n\t}", "@Override\n\tprotected void initialize() {\n\n\t}", "@Override\r\n\tpublic void dispase() {\n\r\n\t}", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "@Override\n\tpublic void dtd() {\n\t\t\n\t}", "@Override\n\tprotected void logic() {\n\n\t}", "@Override\n\tprotected void lazyLoad() {\n\t\t\n\t}", "public void mo4359a() {\n }", "@Override\r\n\tprotected void initialize() {\n\r\n\t}", "@Override\n public void memoria() {\n \n }", "@Override\n\t\tpublic void method() {\n\t\t\t\n\t\t}", "private RepositorioAtendimentoPublicoHBM() {\r\t}", "@Override\n protected void initialize() \n {\n \n }", "@Override\r\n\tpublic void getProposition() {\n\r\n\t}", "@Override\n\tpublic void particular1() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n protected void prot() {\n }", "@Override\r\n\tpublic void init()\r\n\t{\n\t}", "@Override\n\tprotected void initValue()\n\t{\n\n\t}", "public void mo55254a() {\n }" ]
[ "0.6671074", "0.6567672", "0.6523024", "0.6481211", "0.6477082", "0.64591026", "0.64127725", "0.63762105", "0.6276059", "0.6254286", "0.623686", "0.6223679", "0.6201336", "0.61950207", "0.61950207", "0.61922914", "0.6186996", "0.6173591", "0.61327106", "0.61285484", "0.6080161", "0.6077022", "0.6041561", "0.6024072", "0.6020252", "0.59984857", "0.59672105", "0.59672105", "0.5965777", "0.59485507", "0.5940904", "0.59239364", "0.5910017", "0.5902906", "0.58946234", "0.5886006", "0.58839184", "0.58691067", "0.5857751", "0.58503544", "0.5847024", "0.58239377", "0.5810564", "0.5810089", "0.5806823", "0.5806823", "0.5800025", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5790187", "0.5789414", "0.5787092", "0.57844025", "0.57844025", "0.5774479", "0.5774479", "0.5774479", "0.5774479", "0.5774479", "0.5761362", "0.57596046", "0.57596046", "0.575025", "0.575025", "0.575025", "0.5747959", "0.57337177", "0.57337177", "0.57337177", "0.5721452", "0.5715831", "0.57142824", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.5711723", "0.57041645", "0.56991017", "0.5696783", "0.56881124", "0.56774884", "0.56734604", "0.56728", "0.56696945", "0.5661323", "0.5657007", "0.5655942", "0.5655942", "0.5655942", "0.56549734", "0.5654792", "0.5652974", "0.5650185" ]
0.0
-1
TODO Autogenerated method stub
@Override public void remove() { }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n public void perish() {\n \n }", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "@Override\n\tpublic void anular() {\n\n\t}", "@Override\n\tprotected void getExras() {\n\n\t}", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "@Override\n\tprotected void interr() {\n\t}", "@Override\n\tpublic void emprestimo() {\n\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "@Override\n protected void getExras() {\n }", "@Override\r\n\tpublic void publierEnchere() {\n\t\t\r\n\t}", "@Override\n\tpublic void nefesAl() {\n\n\t}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "@Override\n public void func_104112_b() {\n \n }", "@Override\n\tprotected void initdata() {\n\n\t}", "@Override\n\tpublic void nghe() {\n\n\t}", "@Override\n public void function()\n {\n }", "@Override\n public void function()\n {\n }", "public final void mo51373a() {\n }", "@Override\r\n\tpublic void stehReagieren() {\r\n\t\t//\r\n\t}", "@Override\n public void inizializza() {\n\n super.inizializza();\n }", "@Override\n\tprotected void initData() {\n\t\t\n\t}", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "@Override\r\n\tprotected void InitData() {\n\t\t\r\n\t}", "public void designBasement() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "public void gored() {\n\t\t\n\t}", "@Override\r\n\tprotected void initData() {\n\r\n\t}", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n protected void initialize() {\n\n \n }", "public void mo38117a() {\n }", "@Override\n\tprotected void getData() {\n\t\t\n\t}", "Constructor() {\r\n\t\t \r\n\t }", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\n\tpublic void one() {\n\t\t\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "@Override\r\n\tprotected void initData() {\n\t\t\r\n\t}", "private stendhal() {\n\t}", "@Override\n\tprotected void update() {\n\t\t\n\t}", "@Override\n\t\t\tpublic void ic() {\n\t\t\t\t\n\t\t\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tprotected void initData() {\n\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n public void init() {\n\n }", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\n\tpublic void debite() {\n\t\t\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "public contrustor(){\r\n\t}", "@Override\n\tprotected void initialize() {\n\n\t}", "@Override\r\n\tpublic void dispase() {\n\r\n\t}", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "@Override\n\tpublic void dtd() {\n\t\t\n\t}", "@Override\n\tprotected void logic() {\n\n\t}", "@Override\n\tprotected void lazyLoad() {\n\t\t\n\t}", "public void mo4359a() {\n }", "@Override\r\n\tprotected void initialize() {\n\r\n\t}", "@Override\n public void memoria() {\n \n }", "@Override\n\t\tpublic void method() {\n\t\t\t\n\t\t}", "private RepositorioAtendimentoPublicoHBM() {\r\t}", "@Override\n protected void initialize() \n {\n \n }", "@Override\r\n\tpublic void getProposition() {\n\r\n\t}", "@Override\n\tpublic void particular1() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n protected void prot() {\n }", "@Override\r\n\tpublic void init()\r\n\t{\n\t}", "@Override\n\tprotected void initValue()\n\t{\n\n\t}", "public void mo55254a() {\n }" ]
[ "0.6671074", "0.6567672", "0.6523024", "0.6481211", "0.6477082", "0.64591026", "0.64127725", "0.63762105", "0.6276059", "0.6254286", "0.623686", "0.6223679", "0.6201336", "0.61950207", "0.61950207", "0.61922914", "0.6186996", "0.6173591", "0.61327106", "0.61285484", "0.6080161", "0.6077022", "0.6041561", "0.6024072", "0.6020252", "0.59984857", "0.59672105", "0.59672105", "0.5965777", "0.59485507", "0.5940904", "0.59239364", "0.5910017", "0.5902906", "0.58946234", "0.5886006", "0.58839184", "0.58691067", "0.5857751", "0.58503544", "0.5847024", "0.58239377", "0.5810564", "0.5810089", "0.5806823", "0.5806823", "0.5800025", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5792378", "0.5790187", "0.5789414", "0.5787092", "0.57844025", "0.57844025", "0.5774479", "0.5774479", "0.5774479", "0.5774479", "0.5774479", "0.5761362", "0.57596046", "0.57596046", "0.575025", "0.575025", "0.575025", "0.5747959", "0.57337177", "0.57337177", "0.57337177", "0.5721452", "0.5715831", "0.57142824", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.57140535", "0.5711723", "0.57041645", "0.56991017", "0.5696783", "0.56881124", "0.56774884", "0.56734604", "0.56728", "0.56696945", "0.5661323", "0.5657007", "0.5655942", "0.5655942", "0.5655942", "0.56549734", "0.5654792", "0.5652974", "0.5650185" ]
0.0
-1
Created by hienl on 1/9/2017.
public interface IOnOffClick { public void onOffClick(View view, int pos, boolean isOn); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void perish() {\n \n }", "private stendhal() {\n\t}", "public final void mo51373a() {\n }", "@Override\n public void func_104112_b() {\n \n }", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "@Override\n\tprotected void getExras() {\n\n\t}", "public void mo38117a() {\n }", "private void poetries() {\n\n\t}", "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "private static void cajas() {\n\t\t\n\t}", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "private void m50366E() {\n }", "@Override\n\tprotected void interr() {\n\t}", "@Override\n public int describeContents() { return 0; }", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "@Override\n\tpublic void anular() {\n\n\t}", "public void mo4359a() {\n }", "@Override\n public void init() {\n\n }", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "protected boolean func_70814_o() { return true; }", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "@Override\n protected void getExras() {\n }", "@Override\n public void init() {\n }", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "private void init() {\n\n\t}", "@Override\n void init() {\n }", "@Override\n\tpublic void jugar() {\n\t\t\n\t}", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n public void init() {}", "public void gored() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\r\n\tpublic void init() {}", "private Rekenhulp()\n\t{\n\t}", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n protected void init() {\n }", "@Override\n protected void initialize() {\n\n \n }", "private void kk12() {\n\n\t}", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n\tpublic void nghe() {\n\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\n protected void initialize() \n {\n \n }", "@Override\n\tpublic void one() {\n\t\t\n\t}", "@Override\n public void memoria() {\n \n }", "public void mo6081a() {\n }", "@Override\n public void init() {\n\n }", "@Override\n public void init() {\n\n }", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\n\tprotected void initialize() {\n\n\t}", "@Override\n\tpublic void init() {\n\t}", "@Override\r\n\tpublic void init()\r\n\t{\n\t}", "public void mo12930a() {\n }", "public void m23075a() {\n }", "public void mo21877s() {\n }", "@Override\n\tpublic void init()\n\t{\n\n\t}", "protected MetadataUGWD() {/* intentionally empty block */}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "@Override\r\n\tprotected void doF4() {\n\t\t\r\n\t}", "private MetallicityUtils() {\n\t\t\n\t}", "public void mo12628c() {\n }", "@Override\n public int retroceder() {\n return 0;\n }", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "private void strin() {\n\n\t}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "@Override\n\t\tpublic void init() {\n\t\t}", "public abstract void mo70713b();", "@Override public int describeContents() { return 0; }", "public final void mo91715d() {\n }" ]
[ "0.60498875", "0.5959077", "0.5894622", "0.5805883", "0.57947576", "0.57746106", "0.5749896", "0.5749896", "0.5705757", "0.56794053", "0.56624293", "0.562176", "0.5620465", "0.56173813", "0.5609178", "0.56078446", "0.5607101", "0.5601544", "0.55770797", "0.55711854", "0.5558902", "0.55508083", "0.55505794", "0.55478436", "0.5545134", "0.5545134", "0.5545134", "0.5545134", "0.5545134", "0.5542383", "0.55321044", "0.55170316", "0.5504315", "0.54959315", "0.5490284", "0.5481967", "0.54772216", "0.54741997", "0.54608506", "0.5454742", "0.5454742", "0.5454742", "0.5454742", "0.5454742", "0.5454742", "0.54478455", "0.54456156", "0.5444829", "0.5444829", "0.5444094", "0.5437819", "0.5433323", "0.5424521", "0.5424521", "0.5424521", "0.541995", "0.54198635", "0.5417574", "0.5411145", "0.5411145", "0.5411145", "0.5411145", "0.5411145", "0.5411145", "0.5411145", "0.540321", "0.5399561", "0.5397868", "0.5397868", "0.5397868", "0.5396687", "0.5396687", "0.5391969", "0.538957", "0.53870004", "0.5386688", "0.5383004", "0.5383004", "0.5382175", "0.5382175", "0.5382175", "0.5368869", "0.53593194", "0.5355101", "0.53468525", "0.53383607", "0.53376955", "0.5331795", "0.5323841", "0.53220904", "0.53173226", "0.53171015", "0.5316362", "0.5314477", "0.5313008", "0.53094953", "0.5308225", "0.5304273", "0.53008664", "0.529533", "0.52952486" ]
0.0
-1
utilizando su propieos metodos
public void generarCodigo(){ this.setCodigo("c"+this.getNombre().substring(0,3)); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void limpiarCampos() {\n\t\ttema = new Tema();\n\t\ttemaSeleccionado = new Tema();\n\t\tmultimedia = new Multimedia();\n\t}", "private void limpiarDatos() {\n\t\t\n\t}", "public void inicializarListaMascotas()\n {\n //creamos un arreglo de objetos y le cargamos datos\n mascotas = new ArrayList<>();\n mascotas.add(new Mascota(R.drawable.elefante,\"Elefantin\",0));\n mascotas.add(new Mascota(R.drawable.conejo,\"Conejo\",0));\n mascotas.add(new Mascota(R.drawable.tortuga,\"Tortuga\",0));\n mascotas.add(new Mascota(R.drawable.caballo,\"Caballo\",0));\n mascotas.add(new Mascota(R.drawable.rana,\"Rana\",0));\n }", "@Override\n public void memoria() {\n \n }", "private void reposicionarPersonajes() {\n // TODO implement here\n }", "@Override\n\tvoid geraDados() {\n\n\t}", "@Override\n\tpublic void mostrarDados() {\n\t\t\n\t}", "private void habilitarCamposModif() {\n\n listarPromotoresModif();\n //limpiarListaCrear();\n }", "private void creaModuloMem() {\n /* variabili e costanti locali di lavoro */\n ArrayList<Campo> campi = new ArrayList<Campo>();\n ModuloRisultati modulo;\n Campo campo;\n\n try { // prova ad eseguire il codice\n\n campo = CampoFactory.intero(Campi.Ris.codicePiatto.getNome());\n campi.add(campo);\n\n campo = CampoFactory.testo(Campi.Ris.nomePiatto.getNome());\n campo.setVisibileVistaDefault();\n campo.setTitoloColonna(\"piatto\");\n campo.setToolTipLista(\"nome del piatto\");\n campo.decora()\n .etichetta(\"nome del piatto\"); // le etichette servono per il dialogo ricerca\n campo.setLarghezza(250);\n campi.add(campo);\n\n campo = CampoFactory.testo(Campi.Ris.categoria.getNome());\n campo.setVisibileVistaDefault();\n campo.setTitoloColonna(\"categoria\");\n campo.setToolTipLista(\"categoria del piatto\");\n campo.setLarghezza(80);\n campi.add(campo);\n\n campo = CampoFactory.intero(Campi.Ris.quanteVolte.getNome());\n campo.setVisibileVistaDefault();\n campo.setLarghezza(80);\n campo.setTitoloColonna(\"quante volte\");\n campo.setToolTipLista(\n \"quante volte questo piatto è stato offerto nel periodo analizzato\");\n campo.decora().etichetta(\"quante volte\");\n campi.add(campo);\n\n campo = CampoFactory.intero(Campi.Ris.quantiCoperti.getNome());\n campo.setVisibileVistaDefault();\n campo.setTitoloColonna(\"coperti\");\n campo.setToolTipLista(\"numero di coperti che avrebbero potuto ordinare\");\n campo.decora().etichetta(\"n. coperti\");\n campo.setLarghezza(80);\n campi.add(campo);\n\n campo = CampoFactory.intero(Campi.Ris.quanteComande.getNome());\n campo.setVisibileVistaDefault();\n campo.setTitoloColonna(\"comande\");\n campo.setToolTipLista(\"numero di comande effettive\");\n campo.decora().etichetta(\"n. comande\");\n campo.setLarghezza(80);\n campo.setTotalizzabile(true);\n campi.add(campo);\n\n campo = CampoFactory.percentuale(Campi.Ris.gradimento.getNome());\n campo.setVisibileVistaDefault();\n campo.setTitoloColonna(\"gradimento\");\n campo.setToolTipLista(\n \"percentuale di gradimento (è il 100% se tutti i coperti potenziali lo hanno ordinato)\");\n campo.decora().etichetta(\"% gradimento\");\n campo.setLarghezza(80);\n campi.add(campo);\n\n modulo = new ModuloRisultati(campi);\n setModuloRisultati(modulo);\n\n\n } catch (Exception unErrore) { // intercetta l'errore\n Errore.crea(unErrore);\n } // fine del blocco try-catch\n\n }", "public static void main(String[] args) {\n Perro perro = new Perro(1, \"Juanito\", \"Frespuder\", 'M');\n Gato gato = new Gato(2, \"Catya\", \"Egipcio\", 'F', true);\n Tortuga paquita = new Tortuga(3, \"Pquita\", \"Terracota\", 'F', 12345857);\n\n SetJuego equipo = new SetJuego(4, \"Gato equipo\", 199900, \"Variado\", \"16*16*60\", 15, \"Gatos\");\n PelotaMorder pelotita = new PelotaMorder(1, \"bola loca\", 15000, \"Azul\", \"60 diam\");\n\n System.out.println(perro.toString());//ToString original de \"mascotas\"\n System.out.println(gato.toString());//ToString sobrescrito\n System.out.println(paquita.toString());\n\n System.out.println(equipo);//ToString sobrescrito (tambien se ejecuta sin especificarlo)\n System.out.println(pelotita.toString());//Original de \"Juguetes\"\n\n //metodos clase mascota\n perro.darCredito();//aplicado de la interface darcredito\n paquita.darDeAlta(\"Terracota\",\"Paquita\");\n equipo.devolucion(4,\"Gato Equipo\");\n\n //vamos a crear un arraylist\n ArrayList<String> servicios = new ArrayList<String>();\n servicios.add(\"Inyectologia\");\n servicios.add(\"Peluqueria\");\n servicios.add(\"Baño\");\n servicios.add(\"Desparacitacion\");\n servicios.add(\"Castracion\");\n\n System.out.println(\"Lista de servicios: \" + servicios + \", con un total de \" + servicios.size());\n\n servicios.remove(3);//removemos el indice 3 \"Desparacitacion\"\n\n System.out.println(\"Se ha removido un servicio..................\");\n System.out.println(\"Lista de servicios: \" + servicios + \", con un total de \" + servicios.size());\n\n\n //creamos un vector\n Vector<String> promociones = new Vector<String>();\n\n promociones.addElement(\"Dia perruno\");\n promociones.addElement(\"Gatutodo\");\n promociones.addElement(\"10% Descuento disfraz de perro\");\n promociones.addElement(\"Jornada de vacunacion\");\n promociones.addElement(\"Serpiente-Promo\");\n\n System.out.println(\"Lista de promos: \" + promociones);\n System.out.println(\"Total de promos: \" + promociones.size());\n\n promociones.remove(4);//removemos 4 \"Serpiente-Promo\"\n System.out.println(\"Se ha removido una promocion..................\");\n\n System.out.println(\"Lista de promos: \" + promociones);\n System.out.println(\"Total de promos: \" + promociones.size());\n\n String[] dias_Semana = {\"Lunes\",\"Martes\",\"Miercoles\",\"Jueves\",\"Viernes\", \"Sabado\",\"Domingo\"};\n\n try{\n System.out.println(\"Elemento 6 de servicios: \" + dias_Semana[8]);\n } catch (ArrayIndexOutOfBoundsException e){\n System.out.println(\"Ey te pasaste del indice, solo hay 5 elementos\");\n } catch (Exception e){\n System.out.println(\"Algo paso, el problema es que no se que...\");\n System.out.println(\"La siguiente linea ayudara a ver el error\");\n e.printStackTrace();//solo para desarrolladores\n }finally {\n System.out.println(\"------------------------El curso termino! Pero sigue el de Intro a Android!!!!--------------------------\");\n }\n\n }", "public void generTirarDados() {\n\r\n\t}", "private void Mueve() {\n\t\tpaleta1.Mueve_paletas();\n\t\tpaleta2.Mueve_paletas();\n\t\tpelota.Mueve_pelota();\n\t}", "public Controlador() {\n\t\t// m\n\t\tdatosPrueba1 = new ListaEnlazada();\n\t\t// m\n\t\tdatosPrueba2 = new ListaEnlazada();\n\t\t// add\n\t\tdatosPrueba3 = new ListaEnlazada();\n\t\tdatosPrueba4 = new ListaEnlazada();\n\t\tprueba1 = new Estadisticas(datosPrueba1);\n\t\tprueba2 = new Estadisticas(datosPrueba2);\n\t\tprueba3 = new Estadisticas(datosPrueba3);\n\t\tprueba4 = new Estadisticas(datosPrueba4);\n\t\t// finAdd\n\t}", "private void doNovo() {\n contato = new ContatoDTO();\n popularTela();\n }", "public void marcarTodos() {\r\n\t\tfor (int i = 0; i < listaPlantaCargoDto.size(); i++) {\r\n\t\t\tPlantaCargoDetDTO p = new PlantaCargoDetDTO();\r\n\t\t\tp = listaPlantaCargoDto.get(i);\r\n\t\t\tif (!obtenerCategoria(p.getPlantaCargoDet())\r\n\t\t\t\t\t.equals(\"Sin Categoria\"))\r\n\t\t\t\tp.setReservar(true);\r\n\t\t\tlistaPlantaCargoDto.set(i, p);\r\n\t\t}\r\n\t\tcantReservados = listaPlantaCargoDto.size();\r\n\t}", "private void guardarEstadoObjetosUsados() {\n }", "private void mueveObjetos()\n {\n // Mueve las naves Ufo\n for (Ufo ufo : ufos) {\n ufo.moverUfo();\n }\n \n // Cambia el movimiento de los Ufos\n if (cambiaUfos) {\n for (Ufo ufo : ufos) {\n ufo.cambiaMoverUfo();\n }\n cambiaUfos = false;\n }\n\n // Mueve los disparos y los elimina los disparos de la nave Guardian\n if (disparoGuardian.getVisible()) {\n disparoGuardian.moverArriba();\n if (disparoGuardian.getPosicionY() <= 0) {\n disparoGuardian.setVisible(false);\n }\n }\n\n // Dispara, mueve y elimina los disparos de las naves Ufo\n disparaUfo();\n if (disparoUfo.getVisible()) {\n disparoUfo.moverAbajo();\n if (disparoUfo.getPosicionY() >= altoVentana) {\n disparoUfo.setVisible(false);\n }\n }\n\n // Mueve la nave Guardian hacia la izquierda\n if (moverIzquierda) {\n guardian.moverIzquierda();\n }\n // Mueve la nave Guardian hacia la derecha\n if (moverDerecha) {\n guardian.moverDerecha();\n }\n // Hace que la nave Guardian dispare\n if (disparar) {\n disparaGuardian();\n }\n }", "default String getTodo(){\n\t\treturn getPerimetro() + \" - \"+ getNombre();\n\t}", "public void Ordenamiento() {\n\n\t}", "public static void main(String[] args) {\n\n aluno exemplo1 = new aluno();//objeto do tipo aluno\n aluno exemplo2 = new aluno();\n exemplo1.nome = \"EPAMINONDAS\";\n exemplo1.matricula = \"MAT-1\";\n exemplo1.nota = 5;\n exemplo1.anoNacimento = 2005;\n\n\n exemplo2.nome = \"MARIA\";\n exemplo2.matricula = \"MAT-2\";\n exemplo2.nota = 10;\n exemplo2.anoNacimento = 2000;\n\n\n System.out.println(\"Nome: \"+exemplo1.nome + \" matricula: \" + exemplo1.matricula + \" nota: \" + exemplo1.nota);\n System.out.println(\"Nome: \"+exemplo2.nome + \" matricula: \" + exemplo2.matricula + \" nota: \" + exemplo2.nota);\n\n exemplo1.mostraIdade(2030);//metodos\n exemplo2.mostraIdade(2021);\n exemplo2.mostraIdade(2003, 2021);\n }", "public Artefato() {\r\n\t\tthis.membros = new ArrayList<Membro>();\r\n\t\tthis.servicos = new ArrayList<IServico>();\r\n\t}", "private void inicializarVariablesControlRonda() {\n\t\ttieneAs = new int[4];\n\t\tfor(int i=0;i<tieneAs.length;i++) {\n\t\t\ttieneAs[i]=0;\n\t\t}\n\t\tidJugadores = new String[3];\n\t\tvalorManos = new int[4];\n\t\t\n\t\tmazo = new Baraja();\n\t\tCarta carta;\n\t\tganador = new ArrayList<String>();\n\t\tapuestasJugadores = new int[3];\n\t\tmanoJugador1 = new ArrayList<Carta>();\n\t\tmanoJugador2 = new ArrayList<Carta>();\n\t\tmanoJugador3 = new ArrayList<Carta>();\n\t\tmanoDealer = new ArrayList<Carta>();\n\t\tparejaNombreGanancia = new ArrayList<Pair<String,Integer>>(); \n\t\t\n\t\t// gestiona las tres manos en un solo objeto para facilitar el manejo del hilo\n\t\tmanosJugadores = new ArrayList<ArrayList<Carta>>(4);\n\t\tmanosJugadores.add(manoJugador1);\n\t\tmanosJugadores.add(manoJugador2);\n\t\tmanosJugadores.add(manoJugador3);\n\t\tmanosJugadores.add(manoDealer);\n\t\t// reparto inicial jugadores 1 y 2\n\t\tfor (int i = 1; i <= 2; i++) {\n\t\t\tcarta = mazo.getCarta();\n\t\t\tmanoJugador1.add(carta);\n\t\t\tcalcularValorMano(carta, 0);\n\t\t\tcarta = mazo.getCarta();\n\t\t\tmanoJugador2.add(carta);\n\t\t\tcalcularValorMano(carta, 1);\n\t\t\tcarta = mazo.getCarta();\n\t\t\tmanoJugador3.add(carta);\n\t\t\tcalcularValorMano(carta, 2);\n\t\t}\n\t\t// Carta inicial Dealer\n\t\tcarta = mazo.getCarta();\n\t\tmanoDealer.add(carta);\n\t\tcalcularValorMano(carta, 3);\n\n\t\t\n\t}", "public void buscarGestor(){\r\n\t\t\r\n\t}", "public meseros() {\n initComponents();\n }", "private DittaAutonoleggio(){\n \n }", "private void populaAlimento()\n {\n Alimento a = new Alimento(\"Arroz\", 100d, 5d, 0.4d, 30d, 100d, new UnidadeMedida(1));\n alimentoDAO.insert(a);\n a = new Alimento(\"Abacaxi\", 96.2d, 1.2d, 2.3d, 6d, 100d, new UnidadeMedida(1));\n alimentoDAO.insert(a);\n a = new Alimento(\"Carne moida - Acem\", 212.4d, 26.7d, 9.8d, 0d, 100, new UnidadeMedida(1));\n alimentoDAO.insert(a);\n a = new Alimento(\"Pernil Assado\", 262.3d, 32.1d, 13.1d, 0, 100, new UnidadeMedida(1));\n alimentoDAO.insert(a);\n a = new Alimento(\"Pao de forma integral\", 253.2d, 9.4d, 2.9d, 49, 100, new UnidadeMedida(1));\n alimentoDAO.insert(a);\n }", "public ManipularEstudiantes() {\n initComponents();\n cme = new Control_Mantenimiento_Estudiante(this);\n this.gUI_botones2.agregar_eventos(cme);\n }", "@Test \r\n\t\r\n\tpublic void ataqueDeMagoSinMagia(){\r\n\t\tPersonaje perso=new Humano();\r\n\t\tEspecialidad mago=new Hechicero();\r\n\t\tperso.setCasta(mago);\r\n\t\tperso.bonificacionDeCasta();\r\n\t\t\r\n\t\tPersonaje enemigo=new Orco();\r\n\t\tEspecialidad guerrero=new Guerrero();\r\n\t\tenemigo.setCasta(guerrero);\r\n\t\tenemigo.bonificacionDeCasta();\r\n\t\t\r\n\t\tAssert.assertEquals(50,perso.getCasta().getMagia());\r\n\t\tAssert.assertEquals(7,perso.getFuerza());\r\n\t\tAssert.assertEquals(44,perso.getEnergia());\r\n\t\tAssert.assertEquals(17,perso.calcularPuntosDeAtaque());\r\n\t\t\r\n\t\t//ataque normal\r\n\t\tperso.atacar(enemigo);\r\n\t\t\r\n\t\tAssert.assertEquals(50,perso.getCasta().getMagia());\r\n\t\tAssert.assertEquals(7,perso.getFuerza());\r\n\t\tAssert.assertEquals(32,perso.getEnergia());\r\n\t\tAssert.assertEquals(17,perso.calcularPuntosDeAtaque());\r\n\t\t\r\n\t\t// utilizar hechizo\r\n\t\tperso.getCasta().getHechicero().agregarHechizo(\"Engorgio\", new Engorgio());\r\n\t\tperso.getCasta().getHechicero().hechizar(\"Engorgio\",enemigo);\r\n\t\t\r\n\t\tAssert.assertEquals(20,perso.getCasta().getMagia());\r\n\t\tAssert.assertEquals(7,perso.getFuerza());\r\n\t\tAssert.assertEquals(32,perso.getEnergia());\r\n\t\tAssert.assertEquals(17,perso.calcularPuntosDeAtaque());\r\n\t}", "@Override\r\n\tpublic void crearVehiculo() {\n\t\t\r\n\t}", "public static void main(String[] args) {\n\n\t\tMulta_Trafico mt1 = new Multa_Trafico(20, \"B\");\n\t\tmt1.setResponsable(\"Paco\");\n\t\tmt1.setDescripcion(\"Exceso de velocidad\");\n\t\tmt1.setMatricula(\"MK\");\n\t\tmt1.setFecha(\"Viernes\");\n\t\tmt1.verdatos();\n\n\t\tMulta_Covid mc2 = new Multa_Covid(10, \"C\");\n\t\tmc2.setResponsable(\"Pepa\");\n\t\tmc2.setDescripcion(\"No llevaba mascarilla\");\n\t\tmc2.setMascarilla(false);\n\t\tmc2.setFecha(\"Jueves\");\n\t\tmc2.verdatos();\n\n\t\t// Para saber de qué tipo es una clase, objeto, etc... con instanceof\n\t\t// Método saberTipo\n\n\t\tExpediente expe1 = new Expediente(10, \"A\");\n\t\tSystem.out.println(saberTipo(expe1));\n\t\tSystem.out.println(saberTipo(mt1));\n\t\tSystem.out.println(saberTipo(mc2));\n\n\t\tMulta m3 = new Multa(10, \"A\"); // variables del metodo ImporteMayor\n\t\tMulta m4 = new Multa(10, \"B\");\n\t\tm3.setDescripcion(\"Multa\");\n\t\tm3.setResponsable(\"Alberto\");\n\t\tm3.setImporte(200);\n\t\tm4.setImporte(2000);\n\n\t\tSystem.out.println(ImporteMayor(m3, m4));\n\t\tSystem.out.println(conocerTipo(m3));\n\t\tSystem.out.println(m3);\n\n\t\t// array de 50 posiciones para el método MultaMayor\n\n\t\tMulta multas[] = new Multa[50];\n\n\t\tfor (int i = 0; i < multas.length; i++) { // Relleno con descripción e importe\n\t\t\tmultas[i] = new Multa(i, \"A\");\n\t\t\tmultas[i].setDescripcion(\"Descripción\" + i);\n\t\t\tmultas[i].setImporte(Math.random() * 1000 + 25);\n\t\t}\n\t\tSystem.out.println(CalcularMayor(multas));\n\n\t}", "private void populaDiasTreinoCat()\n {\n DiasTreinoCat dias1 = new DiasTreinoCat(\"1 vez por semana\", 1);\n diasTreinoCatDAO.insert(dias1);\n DiasTreinoCat dias2 = new DiasTreinoCat(\"2 vez por semana\", 2);\n diasTreinoCatDAO.insert(dias2);\n DiasTreinoCat dias3 = new DiasTreinoCat(\"3 vez por semana\", 3);\n diasTreinoCatDAO.insert(dias3);\n DiasTreinoCat dias4 = new DiasTreinoCat(\"4 vez por semana\", 4);\n diasTreinoCatDAO.insert(dias4);\n DiasTreinoCat dias5 = new DiasTreinoCat(\"5 vez por semana\", 5);\n diasTreinoCatDAO.insert(dias5);\n DiasTreinoCat dias6 = new DiasTreinoCat(\"6 vez por semana\", 6);\n diasTreinoCatDAO.insert(dias6);\n DiasTreinoCat dias7 = new DiasTreinoCat(\"7 vez por semana\", 7);\n diasTreinoCatDAO.insert(dias7);\n\n }", "@Override\n\tpublic List<Materia> recuperarTodo() throws DataAccessException {\n\t\treturn null;\n\t}", "public void loadTodosMensajes() {\r\n\t\t// Carga mensajes\r\n\t\tinfoDebug(\"Vista\", \"Cargando mensajes\");\r\n\t\tmensajesEntrantes = getTodosMensajesEntrantes(getEmpleadoActual().getEmplId());\r\n\t\tinfoDebug(\"Vista\", \"Acabado\");\r\n\t}", "public GestionTemas() {\n initComponents();\n inicializarComponente();\n cargarTemas();\n }", "@Override\r\n\tpublic void horario() {\n\t\t\r\n\t}", "public void creaAziendaAgricola(){\n\t\tCantina nipozzano = creaCantina(\"Nipozzano\");\t\n\t\tBotte[] bottiNipozzano = new Botte[5+(int)(Math.random()*10)];\t\n\t\tfor(int i=0; i<bottiNipozzano.length; i++){\n\t\t\tbottiNipozzano[i] = creaBotte(nipozzano, i, (int)(Math.random()*10+1), tipologiaBotte[(int)(Math.random()*tipologiaBotte.length)]);\n\t\t}\t\t\n\t\tVigna mormoreto = creaVigna(\"Mormoreto\", 330, 25, EsposizioneVigna.sud, \"Terreni ricchi di sabbia, ben drenati. Discreta presenza di calcio. pH neutro o leggermente alcalino\");\n\t\tFilare[] filariMormoreto = new Filare[5+(int)(Math.random()*10)];\n\t\tfor(int i=0; i<filariMormoreto.length;i++){\n\t\t\tfilariMormoreto[i] = creaFilare(mormoreto, i, tipologiaFilare[(int)(Math.random()*tipologiaFilare.length)]);\n\t\t}\t\n\t\tVigna montesodi = creaVigna(\"Montesodi\", 400, 20, EsposizioneVigna.sud_ovest, \"Arido e sassoso, di alberese, argilloso e calcareo, ben drenato, poco ricco di sostanza organica\");\n\t\tFilare[] filariMontesodi = new Filare[5+(int)(Math.random()*10)];\n\t\tfor(int i=0; i<filariMontesodi.length;i++){\n\t\t\tfilariMontesodi[i] = creaFilare(montesodi, i, tipologiaFilare[(int)(Math.random()*tipologiaFilare.length)]);\n\t\t}\n\t\t/*\n\t\t * CANTINA: POMINO - VIGNETO BENEFIZIO\n\t\t */\n\t\t\n\t\tCantina pomino = creaCantina(\"Pomino\");\n\t\tBotte[] bottiPomino = new Botte[5+(int)(Math.random()*10)];\t\n\t\tfor(int i=0; i<bottiPomino.length; i++){\n\t\t\tbottiPomino[i] = creaBotte(pomino, i, (int)(Math.random()*10+1), tipologiaBotte[(int)(Math.random()*tipologiaBotte.length)]);\n\t\t}\n\t\tVigna benefizio = creaVigna(\"Benefizio\", 700, 9, EsposizioneVigna.sud_ovest, \"Terreni ricchi di sabbia, forte presenza di scheletro. Molto drenanti. Ricchi in elementi minerali. PH acido o leggermente acido.\");\n\t\tFilare[] filariBenefizio = new Filare[5+(int)(Math.random()*10)];\n\t\tfor(int i=0; i<filariBenefizio.length;i++){\n\t\t\tfilariBenefizio[i] = creaFilare(benefizio, i, tipologiaFilare[(int)(Math.random()*tipologiaFilare.length)]);\n\t\t}\n\t\t\n\t\taziendaAgricolaDAO.saveLuogo(nipozzano);\n\t\taziendaAgricolaDAO.saveLuogo(mormoreto);\n\t\taziendaAgricolaDAO.saveLuogo(montesodi);\n\t\t\n\t\taziendaAgricolaDAO.saveLuogo(pomino);\n\t\taziendaAgricolaDAO.saveLuogo(benefizio);\n\t\t\n\t\taziendaAgricolaDAO.saveResponsabile(responsabile(\"Giulio d'Afflitto\"));\n\t\taziendaAgricolaDAO.saveResponsabile(responsabile(\"Francesco Ermini\"));\n\n\t\t\n\t}", "private void mostrarEstadoObjetosUsados() {\n Beneficiario beneficiario = null;\n FichaSocial fichaSocial = null;\n SolicitudBeneficio solicitudBeneficio = null;\n AspectoHabitacional aspectoHabitacional = null;\n AspectoEconomico aspectoEconomico = null;\n\n // CAMBIAR: Obtener datos del Request y asignarlos a los textField\n if (this.getRequestBean1().getObjetoABM() != null) {\n fichaSocial = (FichaSocial) this.getRequestBean1().getObjetoABM();\n aspectoHabitacional = (AspectoHabitacional) fichaSocial.getAspectoHabitacional();\n aspectoEconomico = (AspectoEconomico) fichaSocial.getAspectoEconomico();\n this.getElementoPila().getObjetos().set(0, fichaSocial);\n this.getElementoPila().getObjetos().set(1, aspectoHabitacional);\n this.getElementoPila().getObjetos().set(2, aspectoEconomico);\n }\n\n int ind = 0;\n fichaSocial = (FichaSocial) this.obtenerObjetoDelElementoPila(ind++, FichaSocial.class);\n aspectoHabitacional = (AspectoHabitacional) this.obtenerObjetoDelElementoPila(ind++, AspectoHabitacional.class);\n aspectoEconomico = (AspectoEconomico) this.obtenerObjetoDelElementoPila(ind++, AspectoEconomico.class);\n\n\n this.getTfCodigo().setText(fichaSocial.getNumero());\n this.getTfFecha().setText(Conversor.getStringDeFechaCorta(fichaSocial.getFecha()));\n ////\n //Beneficiarios:\n if (fichaSocial.getTitular() != null) {\n this.getTfTitular().setText(fichaSocial.toString());\n }\n\n this.setListaDelCommunication(new ArrayList(fichaSocial.getGrupoFamiliar()));\n this.getObjectListDataProvider().setList(new ArrayList(fichaSocial.getGrupoFamiliar()));\n\n //Aspecto habitacional:\n if (aspectoHabitacional.getNumeroPersonas() != null) {\n this.getTfNroPersonas().setText(aspectoHabitacional.getNumeroPersonas().toString());\n }\n this.getTfVivienda().setText(aspectoHabitacional.getVivienda());\n this.getTfTenencia().setText(aspectoHabitacional.getTenencia());\n this.getTfNroCamas().setText(aspectoHabitacional.getNumeroCamas());\n this.getTfNroAmbientes().setText(aspectoHabitacional.getNumeroAmbientes());\n this.getCbBanioCompleto().setValue(new Boolean(aspectoHabitacional.isBanioCompleto()));\n this.getCbBanioInterno().setValue(new Boolean(aspectoHabitacional.isBanioInterno()));\n this.getCbAgua().setValue(new Boolean(aspectoHabitacional.isAgua()));\n this.getCbLuz().setValue(new Boolean(aspectoHabitacional.isLuz()));\n this.getCbCloaca().setValue(new Boolean(aspectoHabitacional.isCloaca()));\n this.getCbGasNatural().setValue(new Boolean(aspectoHabitacional.isGasNatural()));\n\n //Aspecto Economico:\n this.getTfNroCasas().setText(aspectoEconomico.getNumeroCasas());\n this.getTfNroTerrenos().setText(aspectoEconomico.getNumeroTerrenos());\n this.getTfNroCampos().setText(aspectoEconomico.getNumeroCampos());\n this.getTfVehiculo().setText(aspectoEconomico.getVehiculo());\n this.getTfIndustria().setText(aspectoEconomico.getIndustria());\n this.getTfActividadLaboral().setText(aspectoEconomico.getActividadLaboral());\n this.getTfComercio().setText(aspectoEconomico.getComercio());\n\n //Solicitud Beneficio\n this.setListaDelCommunication2(new ArrayList(fichaSocial.getListaSolicitudBeneficio()));\n this.getObjectListDataProvider2().setList(new ArrayList(fichaSocial.getListaSolicitudBeneficio()));\n }", "protected void agregarUbicacion(){\n\n\n\n }", "public interface Poulet {\n /*DEFINIT le nombre de like effectué par ce poulet */\n public void setnombreLike(int nombre_like);\n\n /*DEFINIT le nombre de match de ce poulet */\n public void setnombreMatch(int nombre_match);\n\n}", "private void populaNoticiaCat()\n {\n NoticiaCat n1 = new NoticiaCat(\"Avisos\", \"Help\");\n noticiaCatDAO.insert(n1);\n NoticiaCat n2 = new NoticiaCat(\"Noticias\", \"Document Notes\");\n noticiaCatDAO.insert(n2);\n NoticiaCat n3 = new NoticiaCat(\"Dicas\", \"Tag\");\n noticiaCatDAO.insert(n3);\n }", "protected T getManusia(){\r\n return Manusia;\r\n }", "@Override\n public void inizializza() {\n\n super.inizializza();\n }", "private void limpa() {\n\t\t// limpa Alfabeto\n\t\tsimbolos.limpar();\n\t\t// limpa conjunto de estados\n\t\testados.limpar();\n\t\t// limpa Funcao Programa\n\t\tfuncaoPrograma.limpar();\n\t\t// Limpa estados finais\n\t\testadosFinais.limpar();\n\t}", "private void remplirMaterielData() {\n\t}", "public void MieiOrdini()\r\n {\r\n getOrdini();\r\n\r\n }", "void testeAcessos() {\n System.out.println(formaDeFalar);// acessa por herança\n System.out.println(todosSabem);\n }", "@Override\r\n\tprotected void agregarObjeto() {\r\n\t\t// opcion 1 es agregar nuevo justificativo\r\n\t\tthis.setTitle(\"PROCESOS - PERMISOS INDIVIDUALES (AGREGANDO)\");\r\n\t\tthis.opcion = 1;\r\n\t\tactivarFormulario();\r\n\t\tlimpiarTabla();\r\n\t\tthis.panelBotones.habilitar();\r\n\t}", "@Override\n\tpublic void recreo() {\n\n\t}", "public void instantiateTomes(){\n for (String tomeKey : this.getConfig().getConfigurationSection(\"tomes\").getKeys(false)){\n\n if (this.getConfig().getBoolean(\"tomes.\" + tomeKey + \".enabled\") == false){\n continue;\n }\n\n ArrayList<IQuest> questsToAddToTome = new ArrayList<IQuest>();\n for (String questKey : this.getConfig().getConfigurationSection(\"tomes.\" + tomeKey + \".quests\").getKeys(false)){\n for (IQuest quest : quests){\n if (questKey.equalsIgnoreCase(quest.getQuestName())){\n questsToAddToTome.add(quest);\n }\n }\n }\n\n //Fetch rewards of each tome\n ConfigurationSection itemsSection = Tomes.getInstance().getConfig().getConfigurationSection(\"tomes.\" + tomeKey + \".rewards.items\");\n ConfigurationSection weightsSection = Tomes.getInstance().getConfig().getConfigurationSection(\"tomes.\" + tomeKey + \".rewards.weights\");\n\n ArrayList<ItemStack> rewardsArray = new ArrayList<ItemStack>();\n\n if (itemsSection != null) {\n for (String key : itemsSection.getKeys(false)) {\n ItemStack item = itemsSection.getItemStack(key);\n\n for (int i = 0; i < Integer.parseInt(weightsSection.getString(key)); i++) {\n rewardsArray.add(item);\n }\n }\n }\n\n ConfigurationSection tomeConfig = this.getConfig().getConfigurationSection(\"tomes.\" + tomeKey);\n tomes.add(new Tome(\n tomeKey,\n tomeConfig.getString(\"displayName\"),\n tomeConfig.getInt(\"numberOfQuests\"),\n tomeConfig.getInt(\"cost\"),\n questsToAddToTome,\n rewardsArray\n ));\n\n\n }\n }", "private void creerMethode() {\n if (estValide()) {\n methode = new Methode();\n methode.setNom(textFieldNom.getText());\n methode.setVisibilite(comboBoxVisibilite.getValue());\n methode.setType(comboBoxType.getValue());\n ArrayList<Parametre> temp = new ArrayList<>();\n for (Parametre parametre : parametreListView.getItems())\n temp.add(parametre);\n methode.setParametres(temp);\n close();\n }\n }", "@Override\n public String cualquierMetodo2() {\n return \"Método implementado en la clase hija viaje de incentivo\";\n }", "public DAOPedidoMesa() {\n\t\trecursos = new ArrayList<Object>();\n\t}", "public void ganarDineroPorAutomoviles() {\n for (Persona p : super.getMundo().getListaDoctores()) {\n for (Vehiculo v : p.getVehiculos()) {\n v.puedeGanarInteres();\n v.setPuedeGanarInteres(false);\n }\n }\n for (Persona p : super.getMundo().getListaCocineros()) {\n for (Vehiculo v : p.getVehiculos()) {\n v.puedeGanarInteres();\n v.setPuedeGanarInteres(false);\n }\n }\n for (Persona p : super.getMundo().getListaAlbaniles()) {\n for (Vehiculo v : p.getVehiculos()) {\n v.puedeGanarInteres();\n v.setPuedeGanarInteres(false);\n }\n }\n for (Persona p : super.getMundo().getListaHerreros()) {\n for (Vehiculo v : p.getVehiculos()) {\n v.puedeGanarInteres();\n v.setPuedeGanarInteres(false);\n }\n }\n for (Persona p : super.getMundo().getListaCocineros()) {\n for (Vehiculo v : p.getVehiculos()) {\n v.puedeGanarInteres();\n v.setPuedeGanarInteres(false);\n }\n }\n }", "public void datos_elegidos(){\n\n\n }", "protected abstract List<OpcionMenu> inicializarOpcionesMenu();", "void agregarVotoPlayLIst(Voto voto) throws ExceptionDao;", "@Override\r\n\tprotected void init() {\r\n\t\tList<Configuracao> configs = servico.listarTodos();\r\n\t\tif (!configs.isEmpty()) {\r\n\t\t\tentidade = configs.get(0);\t// deve haver apenas um registro\r\n\t\t} else {\r\n\t\t\tcreateConfiguracao();\r\n\t\t}\r\n\t\t\r\n carregarTemas();\r\n\t}", "public List<Mobibus> darMobibus();", "public GestaoFormando() {\n \n initComponents();\n listarEquipamentos();\n listarmapainscritos();\n }", "MotifLearner(){\n notes = new ArrayList<>();\n times = new ArrayList<>();\n }", "@Override\n\tpublic void emprestimo() {\n\n\t}", "public void creoVehiculo() {\n\t\t\n\t\tAuto a= new Auto(false, 0);\n\t\ta.encender();\n\t\ta.setPatente(\"saraza\");\n\t\ta.setCantPuertas(123);\n\t\ta.setBaul(true);\n\t\t\n\t\tSystem.out.println(a);\n\t\t\n\t\tMoto m= new Moto();\n\t\tm.encender();\n\t\tm.frenar();\n\t\tm.setManubrio(true);\n\t\tm.setVelMax(543);\n\t\tm.setPatente(\"zas 241\");\n\t\tVehiculo a1= new Auto(true, 0);\n\t\ta1.setPatente(\"asd 423\");\n\t\t((Auto)a1).setBaul(true);\n\t\t((Auto)a1).setCantPuertas(15);\n\t\tif (a1 instanceof Auto) {\n\t\t\tAuto autito= (Auto) a1;\n\t\t\tautito.setBaul(true);\n\t\t\tautito.setCantPuertas(531);\n\t\t\t\n\t\t}\n\t\tif (a1 instanceof Moto) {\n\t\t\tMoto motito=(Moto) a1;\n\t\t\tmotito.setManubrio(false);\n\t\t\tmotito.setVelMax(15313);\n\t\t\t\n\t\t\t\n\t\t}\n\t\tif (a1 instanceof Camion) {\n\t\t\tCamion camioncito=(Camion) a1;\n\t\t\tcamioncito.setAcoplado(false);\n\t\t\tcamioncito.setPatente(\"ge\");\n\t\t\t\n\t\t\t\n\t\t}\n\t\tVehiculo a2= new Moto();\n\t\tSystem.out.println(a2);\n\t\ta1.frenar();\n\t\t\n\t\tArrayList<Vehiculo>listaVehiculo= new ArrayList<Vehiculo>();\n\t\tlistaVehiculo.add(new Auto(true, 53));\n\t\tlistaVehiculo.add(new Moto());\n\t\tlistaVehiculo.add(new Camion());\n\t\tfor (Vehiculo vehiculo : listaVehiculo) {\n\t\t\tSystem.out.println(\"clase:\" +vehiculo.getClass().getSimpleName());\n\t\t\tvehiculo.encender();\n\t\t\tvehiculo.frenar();\n\t\t\tSystem.out.println(\"=======================================\");\n\t\t\t\n\t\t}\n\t}", "public static void main(String[] args) {\n int op;\r\n int opM;\r\n int opP;\r\n int opA;\r\n int opR;\r\n\r\n //Instanciando clases controladores para acceder a sus constrcutores (CRUD)\r\n ControladorMamifero mamiferoCon = new ControladorMamifero();\r\n ControladorPez pezCon = new ControladorPez();\r\n ControladorAve aveCon = new ControladorAve();\r\n\r\n do {\r\n\r\n System.out.println(\" ►► Menu ◄◄\");\r\n System.out.println(\"1. CRUD> Mamifero\");\r\n System.out.println(\"2. CRUD> Pez\");\r\n System.out.println(\"3. CRUD> Ave\");\r\n System.out.println(\"4. CRUD> Reptil\");\r\n System.out.println(\"5. SALIR \");\r\n\r\n Scanner leer = new Scanner(System.in);\r\n op = leer.nextInt();\r\n\r\n switch (op) {\r\n\r\n case 1: //crud de mamifero\r\n do {\r\n System.out.println(\" ►► Mamifero ◄◄\");\r\n System.out.println(\"1. CREATE \");\r\n System.out.println(\"2. READ \");\r\n System.out.println(\"3. UPDATE \");\r\n System.out.println(\"4. DELETE \");\r\n System.out.println(\"5. LIST \");\r\n System.out.println(\"6. REGRESAR \");\r\n\r\n opM = leer.nextInt();\r\n\r\n switch (opM) {\r\n //Creamos un objeto \"mamifero\".\r\n case 1:\r\n //Creo objeto de la clase ControladorMamifero para \r\n Mamifero mamifero = new Mamifero();\r\n //Asignamos valores\r\n System.out.println(\" CREATE \");\r\n System.out.println(\" Ingresar nombre\");\r\n mamifero.setNombre(leer.nextLine());\r\n mamifero.setNombre(leer.nextLine());\r\n System.out.println(\" Ingresar el tipo de animal\");\r\n mamifero.setTipoAnimal(leer.nextLine());\r\n System.out.println(\" Ingresar el sexo\");\r\n mamifero.setSexo(leer.nextLine());\r\n\r\n System.out.println(\" Ingresar cantidad de patas\");\r\n mamifero.setCantPatas(leer.nextInt());\r\n System.out.println(\" Ingresar cantidad de mamas\");\r\n mamifero.setCantMamas(leer.nextInt());\r\n System.out.println(\" Ingresar el tiempo de gestacion\");\r\n mamifero.setTiempoGest(leer.nextLine());\r\n mamifero.setTiempoGest(leer.nextLine());\r\n System.out.println(\" Ingresar el peso en kilos\");\r\n mamifero.setPeso(leer.nextDouble());\r\n\r\n //llamamos al metodo create en la clase Controlador.\r\n mamiferoCon.create(mamifero);\r\n System.out.println(\" Se ha creado un mamifero \"\r\n + mamifero.getNombre() + \" con el codigo: \" + mamifero.getCodigo());\r\n break;\r\n\r\n //Leemos el objeto creado anteriormente \"mamifero\" mediante el nombre.\r\n case 2:\r\n //Read mamifero\r\n System.out.println(\" \");\r\n System.out.println(\" READ \");\r\n System.out.println(\"Ingresar codigo del mamifero\");\r\n int cod2 = leer.nextInt();\r\n\r\n System.out.println(\" \");\r\n System.out.println(mamiferoCon.read(cod2));\r\n\r\n break;\r\n\r\n //Actualizamos el objeto pidiendo el nombre; el codigo se mantiene. \r\n case 3:\r\n //update mamifero\r\n System.out.println(\" UPDATE \");\r\n Mamifero mamiferoU = new Mamifero();\r\n System.out.println(\"Ingresar codigo del mamifero a modificar \");\r\n mamiferoU.setCodigo(leer.nextInt());\r\n mamiferoCon.update(mamiferoU);\r\n\r\n System.out.println(\"Ingresar nombre:\");\r\n mamiferoU.setNombre(leer.nextLine());\r\n mamiferoU.setNombre(leer.nextLine());\r\n System.out.println(\" Ingresar el tipo de animal\");\r\n mamiferoU.setTipoAnimal(leer.nextLine());\r\n System.out.println(\" Ingresar el sexo\");\r\n mamiferoU.setSexo(leer.nextLine());\r\n\r\n System.out.println(\" Ingresar cantidad de patas\");\r\n mamiferoU.setCantPatas(leer.nextInt());\r\n System.out.println(\" Ingresar cantidad de mamas\");\r\n mamiferoU.setCantMamas(leer.nextInt());\r\n System.out.println(\" Ingresar el tiempo en meses de gestacion\");\r\n mamiferoU.setTiempoGest(leer.nextLine());\r\n mamiferoU.setTiempoGest(leer.nextLine());\r\n System.out.println(\" Ingresar el peso en kilos\");\r\n mamiferoU.setPeso(leer.nextDouble());\r\n\r\n //llama al metodo update de la clase ControladorAuto.\r\n mamiferoCon.update(mamiferoU);\r\n System.out.println(\"Se han actualizado los datos del mamifero de codigo \"\r\n + mamiferoU.getCodigo());\r\n\r\n break;\r\n\r\n //Elimina un objeto y lo buscamos mediante el codigo;\r\n case 4:\r\n //delete mamifero\r\n //Mamifero mamiferoD = new Mamifero();\r\n System.out.println(\" DELETE \");\r\n System.out.println(\" Ingrese el nombre del mamifero a eliminar \");\r\n int cod = leer.nextInt();\r\n //lllama al metodo elimnar de la clase ControladorAuto\r\n mamiferoCon.delete(cod);\r\n System.out.println(\"Se a eliminado el mamifero \" + \" del codigo \" + cod);\r\n\r\n break;\r\n\r\n //Lista todos los objetos en el mismo orden que fueron creados anteriormente. \r\n case 5:\r\n //listar mamiferos creados\r\n System.out.println(\" LISTAR \");\r\n System.out.println(\" Desea listar 1.Si 2.No\");\r\n int lis = leer.nextInt();\r\n //mamifero.listar(leer.nextInt());\r\n mamiferoCon.listar(lis);\r\n\r\n break;\r\n\r\n }\r\n System.out.println(\" \");\r\n System.out.println(\"Continuar en la clase Mamifero = 1.SI / 2.NO\");\r\n opM = leer.nextInt();\r\n\r\n } while (opM != 2);\r\n break;\r\n\r\n //Clase HIJA 2 interface HASHSET y CRUD.\r\n case 2:\r\n do {\r\n System.out.println(\" ►► Pez ◄◄\");\r\n System.out.println(\"1. CREATE \");\r\n System.out.println(\"2. READ \");\r\n System.out.println(\"3. UPDATE \");\r\n System.out.println(\"4. DELETE \");\r\n System.out.println(\"5. LIST \");\r\n System.out.println(\"6. REGRESAR \");\r\n\r\n opP = leer.nextInt();\r\n switch (opP) {\r\n case 1: //create pez\r\n Pez pez = new Pez();\r\n System.out.println(\" CREANDO...\");\r\n System.out.println(\" Ingrese nombre\");\r\n pez.setNombre(leer.nextLine());\r\n pez.setNombre(leer.nextLine());\r\n System.out.println(\"Ingrese tipo de animal\");\r\n pez.setTipoAnimal(leer.nextLine());\r\n System.out.println(\" Ingrese el sexo\");\r\n pez.setSexo(leer.nextLine());\r\n\r\n System.out.println(\"Ingrese el tipo de pez\");\r\n pez.setTipoPez(leer.nextLine());\r\n System.out.println(\"Ingrese el tipo de esqueleto \");\r\n pez.setTipoEsqueleto(leer.nextLine());\r\n System.out.println(\"Ingrese el tamaño\");\r\n pez.setTamaño(leer.nextDouble());\r\n System.out.println(\"Ingrese el peso\");\r\n pez.setPeso(leer.nextDouble());\r\n\r\n pezCon.create(pez);\r\n System.out.println(\" Se ha creado el pez \" + pez.getNombre()\r\n + \" con codigo \" + pez.getCodigo());\r\n\r\n break;\r\n case 2: //read pez\r\n System.out.println(\" \");\r\n System.out.println(\" LEYENDO... \");\r\n System.out.println(\"Ingrese el codigo del pez\");\r\n int cod = leer.nextInt();\r\n\r\n System.out.println(\" \");\r\n //Imprimiendo el objeto \r\n System.out.println(pezCon.read(cod));\r\n\r\n break;\r\n case 3://update pez\r\n Pez pezU = new Pez();\r\n System.out.println(\" \");\r\n System.out.println(\" Ingrese el codigo del pez a modificar\");\r\n pezU.setCodigo(leer.nextInt());\r\n\r\n pezCon.update(pezU);\r\n\r\n System.out.println(\" ACTUALIZANDO...\");\r\n System.out.println(\" Ingrese nombre\");\r\n pezU.setNombre(leer.nextLine());\r\n pezU.setNombre(leer.nextLine());\r\n System.out.println(\"Ingrese tipo de animal\");\r\n pezU.setTipoAnimal(leer.nextLine());\r\n System.out.println(\" Ingrese el sexo\");\r\n pezU.setSexo(leer.nextLine());\r\n\r\n System.out.println(\"Ingrese el tipo de pez\");\r\n pezU.setTipoPez(leer.nextLine());\r\n System.out.println(\"Ingrese el tipo de esqueleto \");\r\n pezU.setTipoEsqueleto(leer.nextLine());\r\n System.out.println(\"Ingrese el tamaño\");\r\n pezU.setTamaño(leer.nextDouble());\r\n System.out.println(\"Ingrese el peso\");\r\n pezU.setPeso(leer.nextDouble());\r\n\r\n System.out.println(\" Los datos se han actualizado correctamente\");\r\n\r\n break;\r\n case 4://delete pez\r\n\r\n Pez pezD = new Pez();\r\n System.out.println(\" ELIMINANDO...\");\r\n System.out.println(\" Ingrese el codigo\");\r\n pezD.setCodigo(leer.nextInt());\r\n\r\n pezCon.delete(pezD);\r\n System.out.println(\" Se ha eliminado el pez de codigo \" + pezD.getCodigo());\r\n\r\n break;\r\n case 5://list pez\r\n System.out.println(\" LISTANDO...\");\r\n pezCon.imprimir();\r\n\r\n break;\r\n\r\n }\r\n System.out.println(\" \");\r\n System.out.println(\" Continuar en la clase PEZ= 1.Si 2.No\");\r\n opP = leer.nextInt();\r\n } while (opP != 2);\r\n break;\r\n\r\n case 3: //CRUD de la clase hija 3 y ademas el CRUD\r\n do {\r\n System.out.println(\" ►► Ave ◄◄\");\r\n System.out.println(\"1. CREATE \");\r\n System.out.println(\"2. READ \");\r\n System.out.println(\"3. UPDATE \");\r\n System.out.println(\"4. DELETE \");\r\n System.out.println(\"5. LIST \");\r\n System.out.println(\"6. REGRESAR \");\r\n\r\n opA = leer.nextInt();\r\n\r\n switch (opA) {\r\n case 1://create ave\r\n Ave ave = new Ave();\r\n System.out.println(\" CREANDO...\");\r\n System.out.println(\" Ingrese el nombre\");\r\n ave.setNombre(leer.nextLine());\r\n ave.setNombre(leer.nextLine());\r\n System.out.println(\"Ingrese tipo de animal\");\r\n ave.setTipoAnimal(leer.nextLine());\r\n System.out.println(\"Ingrese el sexo\");\r\n ave.setSexo(leer.nextLine());\r\n\r\n System.out.println(\"Ingrese color de plumaje\");\r\n ave.setColorPlumaje(leer.nextLine());\r\n System.out.println(\"Ingrese el tipo de ave\");\r\n ave.setTipoAve(leer.nextLine());\r\n System.out.println(\"Ingrese el tamaño\");\r\n ave.setTamaño(leer.nextInt());\r\n System.out.println(\"Ingrese el tiempo de gestacion\");\r\n ave.setTiempoGest(leer.nextLine());\r\n ave.setTiempoGest(leer.nextLine());\r\n\r\n aveCon.create(ave);\r\n System.out.println(\"Se ha creado el ave \" + ave.getNombre()\r\n + \" con el codigo\" + ave.getCodigo());\r\n\r\n break;\r\n\r\n case 2://read ave\r\n System.out.println(\" \");\r\n System.out.println(\"LEYENDO...\");\r\n System.out.println(\" Ingrese el codigo del ave\");\r\n int codA = leer.nextInt();\r\n\r\n System.out.println(aveCon.read(codA));\r\n break;\r\n\r\n case 3://update ave\r\n Ave aveU = new Ave();\r\n System.out.println(\" \");\r\n System.out.println(\" Ingrese el nombre del ave a modificar\");\r\n aveU.setNombre(leer.nextLine());\r\n aveU.setNombre(leer.nextLine());\r\n \r\n aveCon.update(aveU);\r\n\r\n System.out.println(\" ACTUALIZANDO...\");\r\n System.out.println(\" Ingrese el nombre\");\r\n aveU.setNombre(leer.nextLine());\r\n System.out.println(\"Ingrese tipo de animal\");\r\n aveU.setTipoAnimal(leer.nextLine());\r\n System.out.println(\"Ingrese el sexo\");\r\n aveU.setSexo(leer.nextLine());\r\n\r\n System.out.println(\"Ingrese color de plumaje\");\r\n aveU.setColorPlumaje(leer.nextLine());\r\n System.out.println(\"Ingrese el tipo de ave\");\r\n aveU.setTipoAve(leer.nextLine());\r\n System.out.println(\"Ingrese el tamaño\");\r\n aveU.setTamaño(leer.nextInt());\r\n System.out.println(\"Ingrese el tiempo de gestacion\");\r\n aveU.setTiempoGest(leer.nextLine());\r\n aveU.setTiempoGest(leer.nextLine());\r\n \r\n aveCon.update(aveU);\r\n\r\n System.out.println(\"Se han actualizado los datos correctamente\");\r\n break;\r\n\r\n case 4://delete ave\r\n Ave aveD = new Ave();\r\n System.out.println(\" \");\r\n System.out.println(\"ELIMINANDO...\");\r\n System.out.println(\"Ingrese el codigo del ave\");\r\n aveD.setCodigo(leer.nextInt());\r\n\r\n aveCon.delete(aveD);\r\n System.out.println(\" Se ha eliminado el ave de codigo \" + aveD.getCodigo());\r\n break;\r\n\r\n case 5://list todos los objetos creados.\r\n System.out.println(\" LISTANDO...\");\r\n aveCon.imprimir();\r\n break;\r\n }\r\n System.out.println(\" \");\r\n System.out.println(\" Continuar en la clase Ave= 1.Si 2.No\");\r\n opA = leer.nextInt();\r\n } while (opA != 2);\r\n\r\n //case 4:\r\n }\r\n\r\n } while (op != 5);\r\n\r\n }", "private void carregarAgendamentos() {\n agendamentos.clear();\n\n // Carregar os agendamentos do banco de dados\n agendamentos = new AgendamentoDAO(this).select();\n\n // Atualizar a lista\n setupRecyclerView();\n }", "public void listar() {\n\t\t\n\t}", "void inicializarDiccionarioMultiple();", "private void mostrarEmenta (){\n }", "private void iniciarComponentesInterface() {\n\t\tPanelchildren panelchildren = new Panelchildren();\r\n\t\tpanelchildren.setParent(this);\r\n\t\tlistBox = new Listbox();\r\n\t\tlistBox.setHeight(\"300px\");\r\n\t\tlistBox.setCheckmark(true);\r\n\t\tlistBox.setMultiple(false);\r\n\t\tlistBox.setParent(panelchildren);\r\n\t\tListhead listHead = new Listhead();\r\n\t\tlistHead.setParent(listBox);\r\n\t\tListheader listHeader = new Listheader(\"Projeto\");\r\n\t\tlistHeader.setParent(listHead);\r\n\r\n\t\t// Botões OK e Cancelar\r\n\t\tDiv div = new Div();\r\n\t\tdiv.setParent(panelchildren);\r\n\t\tdiv.setStyle(\"float: right;\");\r\n\t\tSeparator separator = new Separator();\r\n\t\tseparator.setParent(div);\r\n\t\tButton botaoOK = new Button(\"OK\");\r\n\t\tbotaoOK.addEventListener(\"onClick\", new EventListenerOK());\r\n\t\tbotaoOK.setWidth(\"100px\");\r\n\t\tbotaoOK.setStyle(\"margin-right: 5px\");\r\n\t\tbotaoOK.setParent(div);\r\n\t\tButton botaoCancelar = new Button(\"Cancelar\");\r\n\t\tbotaoCancelar.addEventListener(\"onClick\", new EventListenerCancelar());\r\n\t\tbotaoCancelar.setWidth(\"100px\");\r\n\t\tbotaoCancelar.setParent(div);\r\n\t}", "private void esvaziaMensageiro() {\n\t\tMensageiro.arquivo=null;\n\t\tMensageiro.lingua = linguas.indexOf(lingua);\n\t\tMensageiro.linguas=linguas;\n\t\tMensageiro.nomeArquivo=null;\n\t}", "private void crearElementos() {\n\n\t\tRotonda rotonda1 = new Rotonda(new Posicion(400, 120), \"5 de octubre\");\n\t\tthis.getListaPuntos().add(rotonda1);\n\n\t\tCiudad esquel = new Ciudad(new Posicion(90, 180), \"Esquel\");\n\t\tthis.getListaPuntos().add(esquel);\n\n\t\tCiudad trelew = new Ciudad(new Posicion(450, 200), \"Trelew\");\n\t\tthis.getListaPuntos().add(trelew);\n\n\t\tCiudad comodoro = new Ciudad(new Posicion(550, 400), \"Comodoro\");\n\t\tthis.getListaPuntos().add(comodoro);\n\n\t\tCiudad rioMayo = new Ciudad(new Posicion(350, 430), \"Rio Mayo\");\n\t\tthis.getListaPuntos().add(rioMayo);\n\n\t\t// --------------------------------------------------------\n\n\t\tRutaDeRipio rutaRipio = new RutaDeRipio(230, 230, rotonda1, esquel);\n\t\tthis.getListaRuta().add(rutaRipio);\n\n\t\tRutaPavimentada rutaPavimentada1 = new RutaPavimentada(380, 100, trelew, comodoro);\n\t\tthis.getListaRuta().add(rutaPavimentada1);\n\n\t\tRutaPavimentada rutaPavimentada2 = new RutaPavimentada(800, 120, esquel, comodoro);\n\t\tthis.getListaRuta().add(rutaPavimentada2);\n\n\t\tRutaDeRipio rutaripio3 = new RutaDeRipio(380, 100, trelew, comodoro);\n\t\tthis.getListaRuta().add(rutaripio3);\n\n\t\tRutaEnConstruccion rutaConst1 = new RutaEnConstruccion(180, 70, rioMayo, comodoro);\n\t\tthis.getListaRuta().add(rutaConst1);\n\n\t\tRutaPavimentada rutaPavimentada3 = new RutaPavimentada(600, 110, rioMayo, esquel);\n\t\tthis.getListaRuta().add(rutaPavimentada3);\n\t}", "private RepositorioOrdemServicoHBM() {\n\n\t}", "Compuesta createCompuesta();", "@Test\n public void cargarMateria_Materias(){\n List<Materia> materias;\n Materia materia;\n \n mt=contAgre.AgregarMateria(imagen, puntos, materiaNombre); \n \n materias= contCons.cargarMateria();\n materia=materias.get(materias.size()-1);\n assertNotNull(materia);\n \n assertEquals(mt.getHijoURL(),materia.getHijoURL());\n assertEquals(mt.getImagenURL(),materia.getImagenURL());\n assertEquals(mt.getNivel(),materia.getNivel());\n assertEquals(mt.getNombre(),materia.getNombre());\n assertEquals(mt.getRepaso(),materia.getRepaso());\n assertEquals(mt.getAsignaturas(),materia.getAsignaturas());\n \n }", "private ControleurAcceuil(){ }", "public static void main(String[] args) {\n Alumnos a = new Alumnos(\"3457794\",\"IDS\",\"A\",3,\"Juan\",\"Masculino\",158);\n //recibe: String folio,String nombre, String sexo, int edad\n Profesores p = new Profesores(\"SDW7984\",\"Dr. Pimentel\",\"Masculino\",25);\n \n //recibe: String puesto,String nombre, String sexo, int edad\n Administrativos ad = new Administrativos(\"Rectoria\",\"Jesica\",\"Femenino\",25);\n \n //datos de alumnos//\n System.out.println(\"\\nEl alumno tiene los siguientes datos:\");\n System.out.println(a.GetName());\n System.out.println(a.GetEdad());\n System.out.println(a.getCarrera());\n \n //datos de maestro//\n System.out.println(\"\\nLos datos de x maestro es:\");\n System.out.println(p.GetName());\n System.out.println(p.getFolio());\n System.out.println(p.GetEdad());\n \n //daros de Administrativo//\n System.out.println(\"\\nLos datos de x Administrativo\");\n System.out.println(ad.GetName());\n System.out.println(ad.getPuesto());\n System.out.println(ad.GetEdad());\n \n \n System.out.println(\"\\n\\nIntegranres de Equipo\");\n System.out.println(\"Kevin Serrano - 133369\");\n System.out.println(\"Luis Angel Farelo Toledo - 143404\");\n System.out.println(\"Ericel Nucamendi Jose - 133407\");\n System.out.println(\"Javier de Jesus Flores Herrera - 143372\");\n System.out.println(\"Carlos Alejandro Zenteno Robles - 143382\");\n }", "private void listadoTipos() {\r\n sessionProyecto.getTipos().clear();\r\n sessionProyecto.setTipos(itemService.buscarPorCatalogo(CatalogoEnum.TIPOPROYECTO.getTipo()));\r\n }", "public static void main(String[]args){\n Carataker carataker=new Carataker();\n //el originator es el creador de los mementos\n Originator originator=new Originator();\n\n ConcreteObject concreteObject;\n\n concreteObject=new ConcreteObject(\"Doc\",\"Titulo\",\"Estado1\");\n originator.setState(concreteObject);\n\n concreteObject=new ConcreteObject(\"Doc\",\"Descripcion\",\"Estado2\");\n originator.setState(concreteObject);\n carataker.addMemento(originator.createMemento()); // [0] Primer estado\n\n concreteObject=new ConcreteObject(\"Doc\",\"Resumen\",\"Estado3\");\n originator.setState(concreteObject);\n\n concreteObject=new ConcreteObject(\"Doc\",\"Conclusion\",\"Estado4\");\n originator.setState(concreteObject);\n carataker.addMemento(originator.createMemento()); //[1] Segundo estado\n\n concreteObject=new ConcreteObject(\"Doc\",\"Bibliografia\",\"Estado5\");\n originator.setState(concreteObject);\n\n //recuperando o restaurando un estado\n\n originator.restoreFromMemento(carataker.getMemento(0));\n\n }", "@Override\n\tpublic void crearNuevaPoblacion() {\n\t\t/* Nos quedamos con los mejores individuos. Del resto, cruzamos la mitad, los mejores,\n\t\t * y el resto los borramos.*/\n\t\tList<IIndividuo> poblacion2 = new ArrayList<>();\n\t\tint numFijos = (int) (poblacion.size()/2);\n\t\t/* Incluimos el 50%, los mejores */\n\t\tpoblacion2.addAll(this.poblacion.subList(0, numFijos));\n\t\t\n\t\t/* De los mejores, mezclamos la primera mitad \n\t\t * con todos, juntandolos de forma aleatoria */\n\t\tList<IIndividuo> temp = poblacion.subList(0, numFijos+1);\n\t\tfor(int i = 0; i < temp.size()/2; i++) {\n\t\t\tint j;\n\t\t\tdo {\n\t\t\t\tj = Individuo.aleatNum(0, temp.size()-1);\n\t\t\t}while(j != i);\n\t\t\t\n\t\t\ttry {\n\t\t\t\tpoblacion2.addAll(cruce(temp.get(i), temp.get(j)));\n\t\t\t} catch (CruceNuloException e) {\n\t\t\t\te.printStackTrace();\n\t\t\t}\n\t\t}\n\t\t\n\t\t//this.poblacion.clear();\n\t\tthis.poblacion = poblacion2;\n\t}", "public void cargarTablas(){\n ControladorEmpleados empleados= new ControladorEmpleados();\n ControladorProyectos proyectos= new ControladorProyectos();\n ControladorCasos casos= new ControladorCasos();\n actualizarListadoObservable(empleados.consultarEmpleadosAdminProyectos(ESTADO_ASIGNADO, TIPO_3),casos.consultarCasos(devolverUser()),casos.consultarTiposCaso());\n }", "public interface PersistenciaSoausentismosInterface {\n /**\n * Método encargado de insertar un Soausentismo en la base de datos.\n * @param soausentismos Soausentismo que se quiere crear.\n */\n public void crear(EntityManager em, Soausentismos soausentismos);\n /**\n * Método encargado de modificar un Soausentismo de la base de datos.\n * Este método recibe la información del parámetro para hacer un 'merge' con la \n * información de la base de datos.\n * @param soausentismos Soausentismo con los cambios que se van a realizar.\n */\n public void editar(EntityManager em, Soausentismos soausentismos);\n /**\n * Método encargado de eliminar de la base de datos el Soausentismo que entra por parámetro.\n * @param soausentismos Soausentismo que se quiere eliminar.\n */\n public void borrar(EntityManager em, Soausentismos soausentismos);\n /**\n * Método encargado de buscar los Soausentismos (EntityManager em, ausentismos) asociados a un empleado específico.\n * @param secuenciaEmpleado Secuencia del empleado para el cual se quieren saber los Soausentismos.\n * @return Retorna una lista de Soausentismos.\n */\n public List<Soausentismos> ausentismosEmpleado (EntityManager em, BigInteger secuenciaEmpleado);\n /**\n * Método encargado de generar un String en formato NUMERO_CERTIFICADO: FECHA_INICIO_AUSENTISMO -> FECHA_FIN_AUSENTISMO\n * con la información del ausentismo cuya secuencia coincide con la del parámetro.\n * @param secuenciaProrroga Secuencia del Ausentismo.\n * @return Retorna un String con el formato descrito y la información del Ausentismo especificado.\n */\n public String prorrogaMostrar(EntityManager em, BigInteger secuenciaProrroga);\n /**\n * Método encargado de buscar los Soausentismos para una lista de valores en la columna prorroga\n * de la tabla Soausentismos. Los Soausentismos que conforman esta lista de valores dependen del\n * empleado, de la causa del ausentismo y del ausentismo asociado a la prorroga.\n * (EntityManager em, Prorroga: ausentismo asociado a un ausentismo específico).\n * @param secuenciaEmpleado Secuencia del empleado\n * @param secuenciaCausa Secuencia de la causa del ausentismo.\n * @param secuenciaAusentismo Secuencia del ausentismo asociado a la prorroga.\n * @return Retorna una lista de los Soausentismos que cumplen con las condiciones anteriores.\n */\n public List<Soausentismos> prorrogas(EntityManager em, BigInteger secuenciaEmpleado, BigInteger secuenciaCausa, BigInteger secuenciaAusentismo);\n \n}", "public void mostrarDados() {\n txtId.setText(\"\" + lista.get(indice).getId());\n txtNome.setText(lista.get(indice).getNome());\n txtEmail.setText(lista.get(indice).getEmail());\n txtSenha.setText(lista.get(indice).getSenha());\n preencheTabela();\n }", "private void carregarAlunosTurma() {\n AcessoFirebase.getFirebase().addListenerForSingleValueEvent(new ValueEventListener() {\n @Override\n public void onDataChange(DataSnapshot dataSnapshot) {\n getUidUsuariosTurma(dataSnapshot);\n montandoArrayListUsuarios(dataSnapshot);\n }\n @Override\n public void onCancelled(DatabaseError databaseError) {\n }\n });\n }", "public void chocoContraMunicion(IMunicion municion){}", "@Override\r\n public List<Assunto> buscarTodas() {\r\n EntityManager em = PersistenceUtil.getEntityManager();\r\n Query query = em.createQuery(\"FROM Assunto As a\");\r\n return query.getResultList();\r\n }", "protected void setManusia(T Manusia){\r\n this.Manusia = Manusia;\r\n }", "private UsineJoueur() {}", "public void inicializar();", "protected abstract void iniciarModo();", "private void manejoDeModales(){\n botonTipo1.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n comprar_es_categoria = false;\n openModalEventHandler(TIPO_MODAL_PATH, txtFieCodigoProducto1);\n });\n botonTipo2.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n obtener_es_categoria = false;\n openModalEventHandler(TIPO_MODAL_PATH, txtFieCodigoProducto2);\n }); \n botonTipo3.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n obtener_es_categoria = false;\n openModalEventHandler(TIPO_MODAL_PATH, txtFieCodigoProducto3);\n }); \n botonCategoria1.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n comprar_es_categoria = true;\n openModalEventHandler(CATEGORIA_MODAL_PATH, txtFieCodigoProducto1);\n }); \n botonCategoria2.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n obtener_es_categoria = true;\n openModalEventHandler(CATEGORIA_MODAL_PATH, txtFieCodigoProducto2);\n }); \n botonCategoria3.addEventHandler(MouseEvent.MOUSE_CLICKED, (event) -> {\n obtener_es_categoria = true;\n openModalEventHandler(CATEGORIA_MODAL_PATH, txtFieCodigoProducto3);\n }); \n }", "public static void main(String[] args){\n //uso correcto de git aaaaa por fin lo comprendi, bueno, por ahora :/...\n\n Perro dog = new Perro(\"Teddy\", \"Callejero\", \"Croquetas\", 2, \"Fuerte\");\n Gato cat = new Gato(\"Miau\", \"Hogareño\", \"Atún\", 1, 7);\n //Perico\n Perico parrot = new Perico(\"Pericles\", \"Loro gris\", \"Galletas\", 1, \"Saludos humanos\");\n //Hamster\n Hamster ham = new Hamster(\"Hamilton\", \"Hamster chino\", \"Apio\", 4, \"Morado\");\n //No recuerdo lol...\n\n //los metodos\n dog.mostrarPerro();\n System.out.println(\"-------\");\n cat.mostrarGato();\n System.out.println(\"-------\");\n parrot.mostrarPerico();\n System.out.println(\"-------\");\n ham.mostrarHamster();\n System.out.println(\"_______\");\n \n }", "public void MostrarDatos(){\n // En este caso, estamos mostrando la informacion necesaria del objeto\n // podemos acceder a la informacion de la persona y de su arreglo de Carros por medio de un recorrido\n System.out.println(\"Hola, me llamo \" + nombre);\n System.out.println(\"Tengo \" + contador + \" carros.\");\n for (int i = 0; i < contador; i++) {\n System.out.println(\"Tengo un carro marca: \" + carros[i].getMarca());\n System.out.println(\"El numero de placa es: \" + carros[i].getPlaca()); \n System.out.println(\"----------------------------------------------\");\n }\n }", "public JanelaTipoContato() {\r\n initComponents();\r\n try {\r\n\r\n List<TipoContato> tipoContatos = (List<TipoContato>) (Object) tipoContatoDao.pesquisarTodos();\r\n adicionarListaTipoContatosTabela(tipoContatos);\r\n } catch (Exception exception) {\r\n }\r\n }", "public void ejecutaMetodo() {\n\t\r\n}", "@Override\r\n\tprotected void initVentajas() {\n\r\n\t}", "public Funcionalidad() {\n Cajero cajero1 = new Cajero(\"Pepe\", 2);\n empleados.put(cajero1.getID(), cajero1);\n Reponedor reponedor1 = new Reponedor(\"Juan\", 3);\n empleados.put(reponedor1.getID(), reponedor1);\n Producto producto1 = new Producto(\"Platano\", 10, 8);\n productos.add(producto1);\n Perecedero perecedero1 = new Perecedero(LocalDateTime.now(), \"Yogurt\", 10, 8);\n }", "public Moto( String nome , float valor , int ano ){\n super( nome , valor ); //define ser uma subclasse\n this.marca = \"Honda\";\n this.ano = ano;\n }", "public nomina()\n {\n deducidoClase = new deducido();\n devengadoClase = new devengado();\n }", "public Celula() { // Sentinela\n\t\tthis.item = new Jogador();\n\t\tproximo = null;\n\t}", "public void createGestionnaireMeubles(){\n this.gestionaireMeubles = new GestionaireMeubles(panneaux.cuisine);\n this.panneaux.leftPanel.getCtrl().bindTotalPrice(this.gestionaireMeubles.totalPricePanierProperty());\n }", "public void ouvrirListe(){\n\t\n}", "public static void main(String[] args) {\n Ator a = new Ator(\"Alberto\");\r\n Ator b = new Ator(\"Vagner moura\");\r\n Ator c = new Ator(\"Ator 1\");\r\n\r\n Filme f= new Filme(\"Tropa de elite\", 2011);\r\n\r\n f.addPapel(a,\"papel 1\", false);\r\n f.addPapel(b,\"papel 2\", true);\r\n f.addPapel(c,\"papel 3\", true);\r\n\r\n\r\n System.out.println(a.getFilmes());\r\n /*System.out.println(f.getProtagonista());\r\n System.out.println(f);\r\n System.out.println(a);\r\n System.out.println(b);\r\n System.out.println(c);*/\r\n\r\n\r\n }" ]
[ "0.6574978", "0.6512046", "0.6356245", "0.62892765", "0.62527716", "0.62165105", "0.61958754", "0.619079", "0.61145973", "0.60928375", "0.6077096", "0.60723877", "0.6067827", "0.59805083", "0.59630424", "0.59408724", "0.5938214", "0.5930232", "0.59088844", "0.58809566", "0.58708155", "0.58627915", "0.5848214", "0.58426505", "0.58239436", "0.5818941", "0.57841104", "0.576792", "0.5759543", "0.57556355", "0.57528055", "0.57515866", "0.5746639", "0.5735557", "0.57301843", "0.570622", "0.5700245", "0.56982106", "0.5693366", "0.5691718", "0.5685471", "0.568545", "0.56823695", "0.56756", "0.5674207", "0.56700796", "0.56595975", "0.5655974", "0.565549", "0.56475747", "0.56426257", "0.5642556", "0.5642308", "0.5637673", "0.5635897", "0.5631781", "0.5627905", "0.5626899", "0.5625026", "0.56169915", "0.56076145", "0.5601082", "0.559762", "0.559525", "0.5594278", "0.5588229", "0.5585316", "0.5583879", "0.55832124", "0.55809855", "0.5580306", "0.5579736", "0.5575835", "0.5567292", "0.55671906", "0.5567161", "0.5565843", "0.5565663", "0.5563447", "0.556264", "0.5561452", "0.5561431", "0.55583787", "0.55561686", "0.5551613", "0.55503565", "0.55465347", "0.5543139", "0.55431217", "0.5542992", "0.55424553", "0.5541716", "0.55417067", "0.5541035", "0.553717", "0.55363494", "0.5531933", "0.55234355", "0.5514404", "0.551212", "0.55118775" ]
0.0
-1
Store All the weather information of a city
@Test(priority = 2) public void WeatherReportForParticularCity() { test.homepage.searchForLocation(ReadWrite.getProperty("Noida_City_State")); test.currentWeatherReportPage.verifyCurrentDayAndTime(); weatherMap = test.currentWeatherReportPage.storeInformationOfWeather(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void handleWeatherDataForCity(String cityName);", "public void getWeather(String city, String units);", "@Override\n\tpublic String getHourlyWeatherData(String city, String country) throws IOException {\n\t\t\n\t\treturn connectFiveDayForecast(city, country);\n\t\t\n\t}", "@Override\n\tpublic String getWeatherDataCity(String city, String country) throws IOException {\n\n\t\treturn connectAPICity(city, country);\n\t\t\n\t}", "public WeatherStation(String city, ArrayList<ie.nuig.stattion.Measurement> Measurement) \n\t{\n\t\tthis.city = city;\n\t\tthis.Measurement = Measurement;\n\t\tstations.add(this);// Every time you make new weather station it will get added to this list\n\t}", "public static boolean save(String city) throws CityNotFoundException {\n\t\tVector<MyData> data = new Vector<MyData>();\n\t\tMyData md = new MyData();\n\t\tFile actualFile = getDir(city);\n\n\t\tmd = (DataWeather.parse(city));\n\t\t\n\t\tdata = getData(actualFile);\n\t\tif(checkDate(data, md)) {\n\t\t\tdata.add(md);\n\t\t\tif(writeData(actualFile, data))\n\t\t\t\treturn true;\n\t\t\treturn false;\t\n\t\t}\n\t\treturn false;\n\t}", "private void searchCity() {\n toggleProgress();\n try {\n WeatherClient client = builder.attach(this)\n .provider(new OpenweathermapProviderType())\n .httpClient(WeatherClientDefault.class)\n .config(config)\n .build();\n\n // Try to find a good location\n // using medium settings\n Criteria criteria = new Criteria();\n criteria.setPowerRequirement(Criteria.POWER_MEDIUM);\n criteria.setAccuracy(Criteria.ACCURACY_MEDIUM);\n // Can we use data?\n criteria.setCostAllowed(true);\n\n // Search city by gps/network using\n // above critera\n client.searchCityByLocation(\n criteria,\n new WeatherClient.CityEventListener() {\n\n // When we get the city list\n @Override\n public void onCityListRetrieved(List<City> cityList) {\n for (int i = 0; i < cityList.size(); i++) {\n adapter.set(cityList.get(i), i);\n }\n displayMessage(\"Not the correct results?\" +\n \" Press the button above to try again.\");\n }\n\n\n @Override\n public void onWeatherError(WeatherLibException wle) {\n displayMessage(\"There seems to be no \" +\n \"weather data, please try again later.\");\n\n }\n\n\n @Override\n public void onConnectionError(Throwable t) {\n displayMessage(\"Whoops! We can't seem to \" +\n \"connect to the weather servers.\");\n }\n\n });\n\n } catch (WeatherProviderInstantiationException e) {\n displayMessage(\"Error: Unable to access \" +\n \"the weather provider.\");\n } catch (LocationProviderNotFoundException e) {\n displayMessage(\"Whoops! Unable to access \" +\n \"location provider.\");\n } catch (NullPointerException e) {\n displayMessage(\"Whoops! We can't seem to\" +\n \"connect to the weather servers.\");\n }\n\n }", "GeneralWeatherReport queryWeatherReport(String cityId);", "public WeatherData (Long sunset, Long sunrise, int weatherCode, String cityName, int temperature) {\n sunsetTime = sunset;\n sunriseTime = sunrise;\n weather = weatherCode;\n city = cityName;\n temp = temperature;\n }", "private void updateWeatherData(final String city){\n new Thread(){\n public void run(){\n final JSONObject json = WeatherJSON.getJSON(getActivity(), city);\n if(json != null){\n handler.post(new Runnable(){\n public void run(){\n renderWeather(json);\n }\n });\n } else {\n\n }\n }\n }.start();\n }", "public List<WeatherCitySummary> findAllCity(){\n return weatherCityRepository.findAllCity();\n }", "private void getWeatherData() {\n System.out.println(\"at getWeather\");\n String url = \"https://api.openweathermap.org/data/2.5/onecall/timemachine?lat=\";\n url += databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LATITUDE);\n url += \"&lon=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LONGITUDE);\n url += \"&dt=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.START_TIME).substring(0, 10);\n url += \"&appid=your openweathermap API key\";\n new ClientThread(ClientThread.GET_WEATHER, new String[]{url, Integer.toString(experimentNumber)}, this).start();\n }", "public void getCityData(String cityName){\n\t\tICityDataService cityDataService = new CityDataService();\n\t\tcityData = cityDataService.getCityData(cityName);\n\t}", "void handleWeatherDataForLocation(String lon, String lat);", "public void getCityResult() {\n String cityNameStr = TextUtils.isEmpty(cityName) ? \"Halifax\" : cityName;\n final String url = \"http://api.openweathermap.org/data/2.5/weather?q=\" + cityNameStr + \"&appid=\" + API_KEY + \"&units=\" + CELSIUS_UNITS;\n //build the request\n JsonObjectRequest request = new JsonObjectRequest(\n Request.Method.GET, url, null, new Response.Listener<JSONObject>() {\n\n @Override\n public void onResponse(JSONObject response) {\n\n try {\n JSONArray weather = response.getJSONArray(\"weather\");\n JSONObject main = response.getJSONObject(\"main\");\n JSONObject cloudsJSON = response.getJSONObject(\"clouds\");\n\n //Set values on layout\n setCityNameOnLayout(response);\n setWeather(weather);\n setTemperature(main);\n setMinMaxTemperature(main);\n setHumidity(main);\n setClouds(cloudsJSON);\n setWeatherIcon((weather.getJSONObject(0)).get(\"icon\").toString());\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n }\n }, new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error) {\n error.printStackTrace();\n\n Toast.makeText(getApplicationContext(), \"Please, introduce an existing city\", Toast.LENGTH_SHORT).show();\n }\n }\n );\n RequestQueueSingleton.getInstance(getApplicationContext()).addToRequestQueue(request);\n }", "@SneakyThrows\n String getTemperature(String city) throws MalformedURLException, IOException {\n double current_temperature = 0;\n JSONObject json = new JSONObject(IOUtils.toString(new URL(\"https://api.openweathermap.org/data/2.5/weather?q=\" + city.toLowerCase(Locale.ROOT) + \"&appid=\"), Charset.forName(\"UTF-8\")));\n current_temperature = (Float.parseFloat(json.getJSONObject(\"main\").get(\"temp\").toString()));\n current_temperature = Math.round(current_temperature*100.0)/100.0;\n System.out.println(json);\n return current_temperature + \"\";\n }", "public void setCity(String city){\n\t\tthis.city = city;\n\t}", "public void setCity(String city){\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "public void setCity(String city) {\n this.city = city;\n }", "@Override\n protected WeatherInfo doInBackground(Void... params) {\n String weatherID = \"\";\n String areaID = \"\";\n try {\n String cityIds = null;\n if (mRequest.getRequestInfo().getRequestType()\n == RequestInfo.TYPE_WEATHER_BY_WEATHER_LOCATION_REQ) {\n cityIds = mRequest.getRequestInfo().getWeatherLocation().getCityId();\n weatherID = cityIds.split(\",\")[0];\n areaID = cityIds.split(\",\")[1];\n } else if (mRequest.getRequestInfo().getRequestType() ==\n RequestInfo.TYPE_WEATHER_BY_GEO_LOCATION_REQ) {\n double lat = mRequest.getRequestInfo().getLocation().getLatitude();\n double lng = mRequest.getRequestInfo().getLocation().getLongitude();\n\n String cityNameResponse = HttpRetriever.retrieve(String.format(GEO_URL, lat, lng));\n if (TextUtils.isEmpty(cityNameResponse)) {\n return null;\n }\n cityNameResponse = cityNameResponse.replace(\"renderReverse&&renderReverse(\", \"\").replace(\")\", \"\");\n Log.d(TAG, \"cityNameResponse\" + cityNameResponse);\n JSONObject jsonObjectCity = JSON.parseObject(cityNameResponse);\n String areaName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"district\");\n String cityName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"city\");\n areaName = TextUtil.getFormatArea(areaName);\n cityName = TextUtil.getFormatArea(cityName);\n City city = cityDao.getCityByCityAndArea(cityName, areaName);\n if (city == null) {\n city = cityDao.getCityByCityAndArea(cityName, cityName);\n if (city == null)\n return null;\n }\n weatherID = city.getWeatherId();\n areaID = city.getAreaId();\n } else {\n return null;\n }\n\n //miui天气\n String miuiURL = String.format(URL_WEATHER_MIUI, weatherID);\n if (DEBUG) Log.d(TAG, \"miuiURL \" + miuiURL);\n String miuiResponse = HttpRetriever.retrieve(miuiURL);\n if (miuiResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"Rmiuiesponse \" + miuiResponse);\n\n //2345天气\n String ttffUrl = String.format(URL_WEATHER_2345, areaID);\n if (DEBUG) Log.d(TAG, \"ttffUrl \" + ttffUrl);\n String ttffResponse = DecodeUtil.decodeResponse(HttpRetriever.retrieve(ttffUrl));\n if (ttffResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"ttffResponse \" + ttffResponse);\n\n\n JSONObject ttffAll = JSON.parseObject(ttffResponse);\n String cityName = ttffAll.getString(\"cityName\");\n //实时\n JSONObject sk = ttffAll.getJSONObject(\"sk\");\n String humidity = sk.getString(\"humidity\");\n String sk_temp = sk.getString(\"sk_temp\");\n\n //日落日升\n JSONObject sunrise = ttffAll.getJSONObject(\"sunrise\");\n\n ArrayList<WeatherInfo.DayForecast> forecasts =\n parse2345(ttffAll.getJSONArray(\"days7\"), true);\n\n WeatherInfo.Builder weatherInfo = null;\n weatherInfo = new WeatherInfo.Builder(\n cityName, sanitizeTemperature(Double.parseDouble(sk_temp), true),\n WeatherContract.WeatherColumns.TempUnit.CELSIUS);\n //湿度\n humidity = humidity.replace(\"%\", \"\");\n weatherInfo.setHumidity(Double.parseDouble(humidity));\n\n if (miuiResponse != null) {\n //风速,风向\n JSONObject weather = JSON.parseObject(miuiResponse);\n JSONObject accu_cc = weather.getJSONObject(\"accu_cc\");\n weatherInfo.setWind(accu_cc.getDouble(\"WindSpeed\"), accu_cc.getDouble(\"WindDirectionDegrees\"),\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH);\n }\n\n weatherInfo.setTimestamp(System.currentTimeMillis());\n weatherInfo.setForecast(forecasts);\n\n if (forecasts.size() > 0) {\n weatherInfo.setTodaysLow(sanitizeTemperature(forecasts.get(0).getLow(), true));\n weatherInfo.setTodaysHigh(sanitizeTemperature(forecasts.get(0).getHigh(), true));\n weatherInfo.setWeatherCondition(IconUtil.getWeatherCodeByType(\n ttffAll.getJSONArray(\"days7\").getJSONObject(0).getString(\n DateTimeUtil.isNight(sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\"))\n ? \"nightWeaShort\" : \"dayWeaShort\"), sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\")));\n }\n\n if (lastWeatherInfo != null)\n lastWeatherInfo = null;\n\n lastWeatherInfo = weatherInfo.build();\n\n return lastWeatherInfo;\n } catch (Exception e) {\n if (DEBUG) Log.w(TAG, \"JSONException while processing weather update\", e);\n }\n return null;\n }", "public void setCity(String city) {\r\n this.city = city;\r\n }", "public void setCity(String city) {\r\n this.city = city;\r\n }", "public void save(String city){\n\n SharedPreferences sp = mcontext.getSharedPreferences(\"city\",Context.MODE_PRIVATE);\n SharedPreferences.Editor editor = sp.edit();\n editor.putString(\"local\",city);\n editor.commit();\n }", "public void setCity(String city)\n\t{\n\t\tCity = city;\n\t}", "public abstract WeatherData getCurrentWeather(LocationCoordinate _location) throws Exception;", "@SuppressWarnings(\"All\")\n void setCity(String city){\n prefs.edit().putString(\"city\", city).commit();\n }", "private void weather() {\n\t\t// System.out.println(\"Sending weather information via Twitter.\");\n\t\t// TwitterComm.sendDirectMessage(Constants.AUTH_USER,\n\t\t// Alfred.getYrParser()\n\t\t// .getWeatherReport().twitterForecastToString());\n\t}", "@Override\n public void run() {\n for(int i=0;i<TheWeatherMan.WEATHER_CHECKS; i++) {\n\n // Have some delay\n try {\n Thread.sleep(1000* startTime);\n } catch (InterruptedException e) {\n System.out.println(\"『 Weather Report 』 Pacific has gone berserk and cant sleep.\\n\" +\n \"Terminating Program...\");\n System.exit(1);\n }\n\n /**\n * Handling Different City Temperatures -------------------------------------------\n */\n\n\n // Handling Singapore Temperatures\n if(cityName == \"Singapore\") {\n\n // Generates a random number between -.3 and .3\n double randNum = (Math.random() * (.6)) - .3;\n // Formats decimals to 2 places\n DecimalFormat df = new DecimalFormat(\"#.##\");\n\n cityTemperature = Double.valueOf(df.format((cityTemperature + randNum)));\n // Set Temp\n ((Satellite) satellite).setWeather1(cityTemperature);\n }\n\n // Handling Melbourne Temperatures\n if(cityName == \"Melbourne\") {\n Random random = new Random();\n double temp = (double) random.nextInt(45) + random.nextDouble();\n\n cityTemperature = temp;\n // Set Temp\n ((Satellite) satellite).setWeather2(cityTemperature);\n }\n\n // Handling Shanghai Temperatures\n if(cityName == \"Shanghai\") {\n\n // Fluctuate +-5\n Random random = new Random();\n double temp = ((double) random.nextInt(5) +\n random.nextDouble()) * (random.nextBoolean() ? 1 : -1);\n\n\n cityTemperature = cityTemperature + temp;\n // Set Temp\n ((Satellite) satellite).setWeather3(cityTemperature);\n }\n\n }\n }", "@GET(\"https://api.openweathermap.org/data/2.5/weather?\")\n Call<WeatherResponse> getWeatherData(@Query(\"q\") String city, @Query(\"appid\") String apiID, @Query(\"units\") String units);", "public List<InputData> getCityData(String city) {\n String SQL = \"SELECT * FROM world_bank WHERE city = ?\";\n List<InputData> records = jdbcTemplate.query(SQL,\n new Object[] { city }, new DataMapper());\n return records;\n }", "public void setCity (String city) {\n\t\tthis.city=city;\n\t}", "public void setCity(String city) {\r\n\t\tthis.city = city;\r\n\t}", "public void setCity(String city) {\r\n\t\tthis.city = city;\r\n\t}", "public abstract WeatherData[] getHourlyWeatherForecast(LocationCoordinate _location) throws Exception;", "public void callAPICall_shouldRetrieveCurrentWeatherInformation(String cityName) {\n\n WeatherAPIManager weatherAPIManager = new WeatherAPIManager(activity);\n weatherAPIManager.setOnResponseListener(new WeatherAPIManagerOnResponseListener());\n weatherAPIManager.connectToWeatherEndpoint(cityName);\n }", "public void setCity(String city) {\n\t\tthis.city = city;\n\t}", "public void setCity(String city) {\n\t\tthis.city = city;\n\t}", "public void setCity(String city) {\n\t\tthis.city = city;\n\t}", "public void setCity(String city) {\n\t\tthis.city = city;\n\t}", "@Cacheable(\"weather\")\r\n\tpublic Weather getWeatherByCityAndCountry(String country, String city) {\n\t\tlogger.info(\"Requesting current weather for {}/{}\", country, city);\r\n\t\t\r\n\t\tURI url = new UriTemplate(WEATHER_URL).expand(city, country, this.apiKey);\r\n\t\treturn invoke(url, Weather.class);\r\n\t}", "void addCity(City city) {\n\n\t\tdatabase.insert(\"city\", null, setCityData(city));\n\t\tdatabase.close();\n\t}", "public void getWeatherData(View view){\n InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n imm.hideSoftInputFromWindow(editText.getWindowToken(), 0);\n\n //get city name from user's input in edittext\n String cityText = editText.getText().toString();\n\n //make sure spaces between words is handled properly\n try {\n String spacedCityName= URLEncoder.encode(cityText, \"UTF-8\");\n //concatenated string for link to be opened\n String link = \"https://openweathermap.org/data/2.5/weather?q=\" + spacedCityName + \"&appid=b6907d289e10d714a6e88b30761fae22\";\n //create Download class to download data\n DownloadClass downloadClass = new DownloadClass();\n downloadClass.execute(link);\n }catch (Exception e){\n loadToast();\n e.printStackTrace();\n }\n\n\n\n }", "public abstract WeatherData[] getDailyWeatherForecast(LocationCoordinate _location) throws Exception;", "@Override\n public City getStatsByCity(String name) throws UnirestException {\n City cityWeather = new City();\n JSONObject object = weatherService.getWeatherByCity(name);\n Coord coord = formatObject(\"coord\",object,Coord.class);\n Wind wind = formatObject(\"wind\",object,Wind.class);\n\n Clouds clouds = formatObject(\"clouds\",object,Clouds.class);\n MainStats mainStats = formatObject(\"main\",object,MainStats.class);\n JSONObject objectWeather = object.getJSONArray(\"weather\").getJSONObject(0);\n Weather weather = mapWeather(objectWeather);\n cityWeather.setCoord(coord);\n cityWeather.setWeather(weather);\n cityWeather.setWind(wind);\n cityWeather.setClouds(clouds);\n cityWeather.setName(object.getString(\"name\"));\n cityWeather.setTimezone(object.getInt(\"timezone\"));\n cityWeather.setCod(object.getInt(\"cod\"));\n cityWeather.setVisibility(object.getInt(\"visibility\"));\n return cityWeather;\n }", "public static ArrayList<Double> getWebTempValues(String city) {\n try {\n return readDoubleDataInJsonFile(getPropertyValue(\"webdata\"), \"$..\" + city.toLowerCase());\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "private void updateWeather() {\n\t\tFetchWeatherTask weatherTask = new FetchWeatherTask(getActivity()); \n\t\tString location = Utility.getPreferredLocation(getActivity());\n\t\tweatherTask.execute(location); \n\t}", "@Test(priority = 3)\n\tpublic void verify_Weather_Data_Appears_OnSearching_By_City() {\n\t\tweatherResponse_city = WeatherAPI.getWeatherInfo(ReadWrite.getProperty(\"Noida_City\"),\n\t\t\t\tConfigFileReader.getProperty(\"appid\"), 200);\n\n\t}", "public synchronized void getWeeklyForecast(String city){\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"Weekly_Forecast\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\t\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = WEEKLY_FORECAST;\r\n\t\tmsg.obj = \"http://api.wunderground.com/auto/wui/geo/ForecastXML/index.xml?query=\".concat(city);\r\n\t\thandler.sendMessage(msg);\r\n\t}", "public void setCity(java.lang.String city) {\n this.city = city;\n }", "public void setCity(java.lang.String city) {\n this.city = city;\n }", "public void addWeather(List<Weather> weatherList) {\n for (Weather item : weatherList) {\n weatherDAO.save(item);\n }\n }", "private List<Tuple> weatherMap(Tuple input) {\n \n Map<String, String> mockLocationService = new HashMap<String, String>();\n mockLocationService.put(\"Harrisburg\", \"PA\");\n mockLocationService.put(\"Pittsburgh\", \"PA\");\n mockLocationService.put(\"Phildelphia\", \"PA\");\n mockLocationService.put(\"Houston\", \"TX\");\n mockLocationService.put(\"SanAntonio\", \"TX\");\n mockLocationService.put(\"Austin\", \"TX\");\n mockLocationService.put(\"Sacramento\", \"CA\");\n mockLocationService.put(\"LosAngeles\", \"CA\");\n mockLocationService.put(\"SanFransico\", \"CA\");\n \n List<Tuple> output = new ArrayList<Tuple>();\n \n String city = input.fst();\n String hiLow = input.snd();\n \n output.add(new Tuple(mockLocationService.get(city), hiLow));\n \n lolligag();\n \n //<state, hi low>\n return output;\n }", "public void setCity(java.lang.String city) {\r\n this.city = city;\r\n }", "public void setCity(City city) {\n this.city = city;\n }", "public void findCities() {\r\n\t\tpolygonMap.setCurrentPlayerID(client.getSettler().getID());\r\n\t\tint counter = 0;\r\n\t\tfor (int i = 0; i < island.getNodes().length; i++) {\r\n\t\t\tif (island.getNodes()[i].getBuilding() == Constants.SETTLEMENT\r\n\t\t\t\t\t&& island.getNodes()[i].getOwnerID() == client.getSettler()\r\n\t\t\t\t\t\t\t.getID()) {\r\n\t\t\t\tpolygonMap.setCityNodes(counter, i);\r\n\t\t\t\tcounter++;\r\n\t\t\t} else {\r\n\t\t\t\tpolygonMap.setCityNodes(counter, -1);\r\n\t\t\t\tcounter++;\r\n\t\t\t}\r\n\t\t}\r\n\t}", "void saveCity(City city);", "String[] getRawWeatherData(String city) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + city + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "void loadData() {\n Request request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=20.5937,78.9629\")\n .get().build();\n //Create OkHttpClient Object\n OkHttpClient client = new OkHttpClient();\n\n // Call the request using client we just created\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n //Use this code to Handle Failed Request mostly due to internet issue\n // we will just Create a Tost Message for user\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n //Here we will check is reponse is Sucessfull or is their any\n // request error i.e url error\n if (!response.isSuccessful()) {\n //Here our reponse is UnSucessfull so we inform the user\n // about the same as before\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n //If Response is sucessfull we move forward and convert the\n // reponse which is in JSON format to String\n String respFromApi = response.body().string();\n\n //We will Log this LogCat in order to view the Raw Format recieved\n //you can open the log cat go in debug section and type RawData you\n // will be able to observe data there\n Log.d(\"RawData\", respFromApi);\n\n //Now We will call Extract Data Function which will retrieve the\n // woied and name of each city from the response\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n //Informing Data is Not in JSON Format\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n ;\n }\n });\n\n\n //---------------------------------FOR United States----------------------------------------\n\n //Following codes has similar output as before but the difference is the city Names here\n //is of United States\n request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=38.899101,-77.028999\")\n .get().build();\n client = new OkHttpClient();\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n if (!response.isSuccessful()) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n String respFromApi = response.body().string();\n Log.d(\"RawData\", respFromApi);\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n\n\n\n }", "private void getHttpResponse() {\n String url = \"https://api.openweathermap.org/data/2.5/weather?id=\"+city.getId()+\"&units=metric&appid=77078c41435ef3379462eb28afbdf417\";\n\n Request request = new Request.Builder()\n .url(url)\n .header(\"Accept\", \"application/json\")\n .header(\"Content-Type\", \"application/json\")\n .build();\n\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Call call, IOException e) {\n String message = e.getMessage();\n System.out.println(message);\n }\n\n /**\n * Update the UI with the information\n * @param call\n * @param response\n * @throws IOException\n */\n @Override\n public void onResponse(Call call, Response response) throws IOException {\n String body = response.body().string();\n\n Gson gson = new Gson();\n CityInfoDto cityInfo = gson.fromJson(body, CityInfoDto.class);\n\n setNewValues(Math.round(cityInfo.main.temp), cityInfo.weather[0].main);\n setBackground();\n }\n });\n }", "@Override\n\t\tprotected GetWeatherRes doInBackground(Void... params) {\n\t\t\treturn JsonOA.getWeatherInfo(cityId, timeStamp);\n\t\t}", "private static void initCityMapping() {\n try {\n log.info(\"initCityMapping start.....\");\n try {\n File dicFile = new File(\"/config/gj_city.json\");\n if (dicFile.exists()) {\n String dic = FileCopyUtils.copyToString(new InputStreamReader(\n new FileInputStream(dicFile),\n StandardCharsets.UTF_8));\n cityInfos = JSONObject.parseObject(dic, Map.class);\n }\n } catch (Exception e) {\n log.error(\"加载城市信息失败,{}\", e.getMessage(), e);\n e.printStackTrace();\n }\n log.info(\"initCityMapping end.....\");\n } catch (Exception e) {\n log.info(\"初始化城市字典数据失败!\", e);\n }\n }", "public ArrayList<Weather> getDarkSkyWeather(String longitude, String latitude) {\n\n Log.i(\"long: \", longitude);\n Log.i(\"lat: \", latitude);\n\n Weather weather = new Weather();\n ArrayList<Weather> weatherArr = new ArrayList<Weather>();\n ArrayList<String> temp = new ArrayList<String>();\n String content;\n try {\n content = weather.execute(\"https://api.darksky.net/forecast/a4b289aa3abfbee48b4fc1df98208a34/\"+ latitude + \",\" + longitude + \"?lang=vi&exclude=minutely,flags,currently\").get();\n\n if(content == null)\n {\n return null;\n }\n JSONObject obj = new JSONObject(content);\n\n JSONObject daily = obj.getJSONObject(\"daily\");\n JSONArray dataDaily = daily.getJSONArray(\"data\");\n\n String summary;\n String temperatureMin;\n String temperatureMax;\n String humidity;\n String windSpeed;\n String windGust;\n String airPressure;\n String visibility;\n String ozoneDensity;\n String uvIndex;\n String cloudCover;\n String precipProbability;\n String time;\n\n Bundle bundle2 = new Bundle();\n images = new Integer[dataDaily.length()];\n\n for(int i = 0; i < dataDaily.length(); i++)\n {\n Weather result = new Weather();\n\n JSONObject detail = dataDaily.getJSONObject(i);\n\n summary = detail.getString(\"summary\");\n temperatureMin = detail.getString(\"temperatureMin\");\n temperatureMax = detail.getString(\"temperatureMax\");\n precipProbability = detail.getString(\"precipProbability\");\n humidity = detail.getString(\"humidity\");\n windSpeed = detail.getString(\"windSpeed\");\n windGust = detail.getString(\"windGust\");\n airPressure = detail.getString(\"pressure\");\n visibility = detail.getString(\"visibility\");\n ozoneDensity = detail.getString(\"ozone\");\n uvIndex = detail.getString(\"uvIndex\");\n cloudCover = detail.getString(\"cloudCover\");\n time = unixTimeToDate(detail.getString(\"time\"));\n\n\n String precipProb = String.valueOf(String.format(\"%.0f\", (Float.parseFloat(precipProbability)*100))+ \"%\");\n\n // Update UI\n result.setDate(normalizeDate(time.substring(0, 10)));\n result.setWeather(summary);\n result.setDescription(\"Khả năng mưa: \" + precipProb);\n result.setTemperature(celsiusToFahrenheit(temperatureMax) + \"\\u2103\");\n result.setWind(\"Gió: \" + windSpeed + \"mph\");\n weatherArr.add(result);\n\n if(summary.toLowerCase().contains(\"quang\"))\n {\n images[i] = R.drawable.sunny;\n }\n if(summary.toLowerCase().contains(\"mưa\"))\n {\n images[i] = R.drawable.rainy;\n }\n else if (summary.toLowerCase().contains(\"âm u\"))\n {\n images[i] = R.drawable.foggy;\n }\n else if (summary.toLowerCase().contains(\"mây\"))\n {\n images[i] = R.drawable.cloudy;\n }\n else\n {\n images[i] = R.drawable.sunny;\n }\n\n\n// Bundle bundlee = new Bundle();\n// ArrayList<String> dailyData = new ArrayList<String>();\n//\n// dailyData.add(summary);\n// dailyData.add(precipProb);\n// dailyData.add(normalizeDate(time.substring(0, 10)));\n// dailyData.add(temperatureMin +\"\\u2103\");\n// dailyData.add(temperatureMax +\"\\u2103\");\n// dailyData.add(humidity + \"%\");\n// dailyData.add(windSpeed + \" mph\");\n// dailyData.add(windGust + \" mph\");\n// dailyData.add(airPressure + \" mb\");\n// dailyData.add(visibility + \" mi\");\n// dailyData.add(ozoneDensity + \" DU\");\n// dailyData.add(uvIndex);\n// dailyData.add(cloudCover);\n// dailyData.add(String.valueOf(i)); // fragment-tag\n//\n// bundlee.putStringArrayList(\"daily-data\",dailyData);\n\n\n Bundle bundle = new Bundle();\n bundle.putString(\"weather\", summary);\n bundle.putString(\"PoP\", precipProb);\n bundle.putString(\"date\", normalizeDate(time.substring(0, 10)));\n bundle.putString(\"tempMin\", temperatureMin +\"\\u2103\");\n bundle.putString(\"tempMax\", temperatureMax +\"\\u2103\");\n bundle.putString(\"humidity\", humidity + \"%\");\n bundle.putString(\"windSpeed\", windSpeed + \" mph\");\n bundle.putString(\"winGust\", windGust + \" mph\");\n bundle.putString(\"airPressure\", airPressure + \" mb\");\n bundle.putString(\"visibility\", visibility + \" mi\");\n bundle.putString(\"ozoneDensity\", ozoneDensity + \" DU\");\n bundle.putString(\"uvIndex\", uvIndex);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTag\", String.valueOf(i));\n\n temp.add(temperatureMin);\n\n bundleDailyArr.add(bundle);\n// bundleDailyArr.add(bundlee);\n\n// Log.i(\"Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n for(int i = 0; i < temp.size(); i++)\n {\n bundle2.putString(\"temp\"+String.valueOf(i), temp.get(i));\n }\n\n\n\n// Get weather hourly\n\n JSONObject hourly = obj.getJSONObject(\"hourly\");\n JSONArray dataHourly = hourly.getJSONArray(\"data\");\n String temperature;\n\n for(int i = 0; i < dataHourly.length(); i++)\n {\n JSONObject detail = dataHourly.getJSONObject(i);\n\n temperature = detail.getString(\"temperature\");\n precipProbability = detail.getString(\"precipProbability\");\n windSpeed = detail.getString(\"windSpeed\");\n cloudCover = detail.getString(\"cloudCover\");\n\n Bundle bundle = new Bundle();\n bundle.putString(\"PoP\", precipProbability);\n //bundle.putString(\"temp\", String.valueOf((int)(Float.parseFloat(temperatureMin) + Float.parseFloat(temperatureMax) / 2)));\n bundle.putString(\"temperature\", temperature);\n bundle.putString(\"windSpeed\", windSpeed);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTagasd\", String.valueOf(i));\n\n\n bundleHourlyArr.putBundle(String.valueOf(i),bundle);\n\n\n Log.i(\"Hourly Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n return weatherArr;\n }", "public void setLocationCity(String locationCity) {\n this.locationCity = locationCity;\n }", "public void setCity (java.lang.String city) {\n\t\tthis.city = city;\n\t}", "void updateForecast(DarkSkyApi api, PlaceWeather weather){\n\n long now = Calendar.getInstance().getTimeInMillis()/1000;\n\n deleteObsoleteEntries(now);\n\n long placeId = weather.getId();\n long currentDay = databaseInstance.weatherDao().selectObsoleteDayCount(now);\n long daysSaved = databaseInstance.weatherDao().selectDayCount();\n\n //check if need to load data\n if(daysSaved - currentDay < 7){\n\n List<HourlyData> hourlyData;\n\n String apiKey = context.getString(R.string.api_key);\n Map<String, String> avoid = new HashMap<>();\n avoid.put(\"units\", \"si\");\n avoid.put(\"lang\", \"en\");\n avoid.put(\"exclude\", \"alerts,daily\");\n\n long currentTime = weather.getDaily().getData().get(\n weather.getDaily().getData().size()-1\n ).getTime() + 1;\n\n //load days\n for(long day = daysSaved - currentDay; day < 7; ++day){\n currentTime += 3600 * 24;\n PlaceWeather nextDay;\n try{\n nextDay = api.getTimeForecast(apiKey,\n weather.getLatitude(),\n weather.getLongitude(),\n now, avoid).execute().body();\n }catch (IOException e){\n //log network failure\n break;\n }\n\n nextDay.getDaily().getData().get(0).setParentPlaceId(placeId);\n\n long nextDailyDataId =\n databaseInstance.weatherDao().insertDailyData(\n nextDay.getDaily().getData().get(0)\n );\n\n nextDay.getHourly().setParentDayId(nextDailyDataId);\n nextDay.getHourly().setId(\n databaseInstance.weatherDao().insertHourly(nextDay.getHourly())\n );\n\n hourlyData = nextDay.getHourly().getData();\n\n for(int j = 0; j < hourlyData.size(); ++j){\n hourlyData.get(j).setParentDayId(nextDailyDataId);\n databaseInstance.weatherDao().insertHourlyData(hourlyData.get(j));\n }\n }\n }\n }", "@Cacheable(\"darkSkyTemperature\")\n public WeatherDataDto getTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(getServiceName());\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Override\r\n\tpublic void buildCity() {\n\t\t\r\n\t}", "public void setWeather(String W){\n weatherID = W ;\n }", "public void setCity(City city) {\n\t\tthis.city = city;\n\t}", "public String getCity() {\n return city;\n }", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "private void updateWeatherView(String cityName){\n\t\t\t\n\t\t\tif (cityName.equals(\"--Remove?--\")){\n\t\t\t\t\tint count = 0;\n\t\t\t\t\tJFrame frame = new JFrame();\n\t\t\t\t\tString[] possibilities = new String[app.getMyLocations().length];\n\t\t\t\t\tfor (int i = 0; i < app.getMyLocations().length; i ++){\n\t\t\t\t\t\tlocation loc = app.getMyLocations()[i];\n\t\t\t\t\t\tif (!loc.getName().equals(\"Default\")){\n\t\t\t\t\t\t\tpossibilities[i] = loc.getName() + \", \" + loc.getCountryCode() + \" Lat: \" + loc.getLatitude()\n\t\t\t\t\t\t\t\t\t+ \" Long: \" + loc.getLongitude();\n\t\t\t\t\t\t\tcount ++;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tString response = (String) JOptionPane.showInputDialog(frame, \"Pick a location to remove:\", \"Remove Location\", \n\t\t\t\t\t\t\tJOptionPane.QUESTION_MESSAGE, null, Arrays.copyOfRange(possibilities, 0, count), \"Titan\");\n\t\t\t\t\tif (response != null){\n\t\t\t\t\t\tString countryCode = response.substring(response.indexOf(',') + 2, response.indexOf(',') + 5);\n\t\t\t\t\t\tcityName = response.substring(0, response.indexOf(','));\n\t\t\t\t\t\tapp.removeLocation(cityName, countryCode);\n\t\t\t\t\t}\n\t\t\t\t\tlocBar.removeActionListener(Jcombo);\n\t\t\t\t\tpopulateMyLocationsBox();\n\t\t\t\t\t\t\n\t\t\t } else if (cityName.equals(\"--Empty--\")){\n\t\t\t\t\t\t//Do nothing\n\t\t\t} else {\n\t\t\t\t\tlocation update = new location();\n\t\t\t\t\tString countryCode = cityName.substring(cityName.indexOf(',') + 2, cityName.indexOf(',') + 4);\n\t\t\t\t\tcityName = cityName.substring(0, cityName.indexOf(','));\n\t\t\t\t\tfor (int i = 0; i < app.getMyLocations().length; i ++){\n\t\t\t\t\t\tString checkName = app.getMyLocations()[i].getName();\n\t\t\t\t\t\tString checkCode = app.getMyLocations()[i].getCountryCode();\n\t\t\t\t\t\tif (checkName.equals(cityName) && checkCode.equals(countryCode)){\n\t\t\t\t\t\t\tupdate = app.getMyLocations()[i];\n\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t}\n\t\t\t\t\t}\n\t\t\t\t\tapp.setVisibleLocation(update);\n\t\t\t\t\trefreshPanels();\n\t\t\t}\n\t\t}", "private static boolean fetchYahooWeather() {\n try {\n SAXParserFactory spf = SAXParserFactory.newInstance();\n spf.setNamespaceAware(true);\n SAXParser parser = spf.newSAXParser();\n \n String yql_format = String.format(\"select %%s from %%s where woeid in (select woeid from geo.places(1) where text=\\\"%s, %s\\\")\", CITY, ST);\n \n /* Fetch Wind Data (temp, windDir, and windSpeed) */\n String yql_wind = String.format(yql_format, \"wind\", \"weather.forecast\");\n String url_wind = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_wind, \"UTF-8\"));\n \n DefaultHandler wind_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:wind\")) return;\n \n temp = Integer.parseInt(attributes.getValue(\"chill\"));\n \n int dir = Integer.parseInt(attributes.getValue(\"direction\")); // number from 0-359 indicating direction\n // I began writing an if tree, then remembered I was lazy.\n String[] dir_words = new String[] {\n \"east\", \"northeast\", \"north\", \"northwest\", \"west\", \"southwest\", \"south\", \"southeast\"\n };\n windDir = dir_words[dir/45];\n \n windSpeed = Integer.parseInt(attributes.getValue(\"speed\")); // speed in mph\n }\n };\n parser.parse(url_wind, wind_handler);\n \n /* Fetch Atronomy Data (sunriseHour and sunsetHour) */\n String yql_astro = String.format(yql_format, \"astronomy\", \"weather.forecast\");\n String url_astro = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_astro, \"UTF-8\"));\n \n DefaultHandler astro_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:astronomy\")) return;\n \n sunriseHour = Util.parseTime(attributes.getValue(\"sunrise\"));\n sunsetHour = Util.parseTime(attributes.getValue(\"sunset\"));\n \n }\n };\n parser.parse(url_astro, astro_handler);\n \n /* Fetch Description Data (sky) */\n String yql_sky = String.format(yql_format, \"item.condition.text\", \"weather.forecast\");\n String url_sky = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_sky, \"UTF-8\"));\n \n DefaultHandler sky_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:condition\")) return;\n \n sky = attributes.getValue(\"text\").toLowerCase();\n \n }\n };\n parser.parse(url_sky, sky_handler);\n \n return E.sky != null;\n \n } catch (java.net.UnknownHostException uhe) {\n if (Data.DEBUG) System.err.println(\"You are offline!\");\n return false;\n } catch (Exception e) {\n e.printStackTrace();\n return false;\n }\n }", "private void initializeWeatherData() {\n Weather location = new Weather(getActivity());\n\n // Make sure the user has put in a location.\n if (location.getName() != null) {\n // Fetch the current forecast, which updates current conditions and weekly forecast.\n GetWeather.getWeatherData(location.getLatitudeLongitude(), adapter, getString(R.string.dark_sky_api), this);\n\n // Set the text on the location label.\n TextView locationLabel = (TextView) getView().findViewById(R.id.text_location_name);\n locationLabel.setText(location.getName());\n\n // If they haven't, ask them to put in a location.\n } else {\n ManualEntry addCityDialogFragment = new ManualEntry().newInstance();\n\n if (!addCityDialogFragment.isActive()) {\n addCityDialogFragment.show(getFragmentManager(), \"fragment_add_city\");\n }\n }\n\n/**\n * In the future, if we want to change their location, can enter another address.\n */\n// ImageButton imageButton = (ImageButton) getView().findViewById(R.id.imageButton);\n// imageButton.setOnClickListener(new View.OnClickListener() {\n// @Override\n// public void onClick(View v) {\n// ManualEntry addCityDialogFragment = new ManualEntry().newInstance();\n// if (!addCityDialogFragment.isActive()) {\n// addCityDialogFragment.show(getFragmentManager(), \"fragment_add_city\");\n// }\n// }\n// });\n }", "public String getCity() {\r\n\t\treturn city;\t\t\r\n\t}", "@Override\n public void requestWeatherSuccess(Weather weather, Location requestLocation) {\n try {\n if (request != null) {\n List<WeatherInfo.DayForecast> forecastList = new ArrayList<>();\n for (int i = 0; i < weather.dailyList.size(); i++) {\n forecastList.add(\n new WeatherInfo.DayForecast.Builder(\n WeatherConditionConvertHelper.getConditionCode(\n weather.dailyList.get(i).weatherKinds[0],\n true))\n .setHigh(weather.dailyList.get(i).temps[0])\n .setLow(weather.dailyList.get(i).temps[1])\n .build());\n }\n WeatherInfo.Builder builder = new WeatherInfo.Builder(\n weather.base.city,\n weather.realTime.temp,\n WeatherContract.WeatherColumns.TempUnit.CELSIUS)\n .setWeatherCondition(\n WeatherConditionConvertHelper.getConditionCode(\n weather.realTime.weatherKind,\n TimeManager.getInstance(this)\n .getDayTime(this, weather, false)\n .isDayTime()))\n .setTodaysHigh(weather.dailyList.get(0).temps[0])\n .setTodaysLow(weather.dailyList.get(0).temps[1])\n .setTimestamp(weather.base.timeStamp)\n .setHumidity(\n Double.parseDouble(\n weather.index.humidities[1]\n .split(\" : \")[1]\n .split(\"%\")[0]))\n .setWind(\n Double.parseDouble(weather.realTime.windSpeed.split(\"km/h\")[0]),\n weather.realTime.windDegree,\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH)\n .setForecast(forecastList);\n\n request.complete(new ServiceRequestResult.Builder(builder.build()).build());\n }\n } catch (Exception ignore) {\n requestWeatherFailed(requestLocation);\n }\n }", "public void downloadWeatherForCurrentLocation() {\n if(checkConnection()) {\n LocationManager locationManager = LocationManager.getInstance(this, view);\n locationManager.getCoordinates();\n } else {\n showNoConnectionDialog();\n }\n }", "public String getCity() {\r\n\t\treturn city;\r\n\t}", "public String getCity() {\r\n\t\treturn city;\r\n\t}", "public Weather getDetails(String cityName) throws SQLException, JSONException {\n Weather wSO = weatherService.getWeatherService(cityName);\n List<Cities> citySO = cityRepository.getCityDetails(cityName);\n\n return extractCityDetails(wSO, citySO);\n }", "private void refreshList() {\n\t\tString cityName = cityWeatherPreferences.getString(\"cityweathername\",\n\t\t\t\tnull);\n\t\tif (cityName != null) {\t\t\n\t\t\tcityTv.setText(cityName.substring(cityName.indexOf(\"-\") + 1));\n\t\t}\n\t\tString tempStr=weatherPreferences.getString(\"temperatureStr\", null);\n\t\tString airIfStr=weatherPreferences.getString(\"airInfoStr\", null);\n\t\tString airPmStr=weatherPreferences.getString(\"airPMStr\", null);\n\t\tString humiStr=weatherPreferences.getString(\"humidityStr\", null);\n\t\tString visiStr=weatherPreferences.getString(\"visibilyStr\", null);\n\t\tString winStr=weatherPreferences.getString(\"windStr\", null);\n\t\tString chyMakStr=weatherPreferences.getString(\"chuangyiMakStr\", null);\n\t\tString chyiAdviceStr=weatherPreferences.getString(\"chuanyiAdviceStr\", null);\n\t\tString ydMarkStr=weatherPreferences.getString(\"yundongMarkStr\", null);\n\t\tString ydAdaviceStr=weatherPreferences.getString(\"yundongAdaviceStr\", null);\n\t\tString gmMarkStr=weatherPreferences.getString(\"ganmaoMarkStr\", null);\n\t\tString gmAdaviceStr=weatherPreferences.getString(\"ganmaoAdaviceStr\", null);\n\t\tString wrMarkStr=weatherPreferences.getString(\"wuranMarkStr\", null);\n\t\tString wrAdaviceStr=weatherPreferences.getString(\"wuranAdaviceStr\", null);\n\t\tString zwxMarkStr=weatherPreferences.getString(\"ziwaixianMarkStr\", null);\n\t\tString zwxAdaviceStr=weatherPreferences.getString(\"ziyaixianAdaviceStr\", null);\n\t\tString ktMarkStr=weatherPreferences.getString(\"kongtiaoMarkStr\", null);\n\t\tString ktAdaviceStr=weatherPreferences.getString(\"kongtiaoAdaviceStr\", null);\n\t\tString xchMarkStr=weatherPreferences.getString(\"xicheMarkStr\", null);\n\t\tString xchAdaviceStr=weatherPreferences.getString(\"xicheAdaviceStr\", null);\n\t\tString wf=weatherPreferences.getString(\"weatherFutrues\", null);\n\t\tif(tempStr!=null&&airIfStr!=null&&airPmStr!=null&&humiStr!=null&&visiStr!=null&&winStr!=null&&wf!=null){\n\t\t\tsetDataToFragment(tempStr,airIfStr,airPmStr,humiStr,visiStr,winStr,\n\t\t\t\t\tchyMakStr,chyiAdviceStr,ydMarkStr,ydAdaviceStr,\n\t\t\t\t\tgmMarkStr,gmAdaviceStr,wrMarkStr,wrAdaviceStr,\n\t\t\t\t\tzwxMarkStr,zwxAdaviceStr,ktMarkStr,ktAdaviceStr,\n\t\t\t\t\txchMarkStr,xchAdaviceStr,PreferencesSaveList.String2SceneList(wf));\n\t\t}\n\t}", "public void addCity(String city) {\n connects.put(city, new ArrayList<Flight>());\n }", "String getIPGeolocationCityDatabaseFile();", "public void read_india_states() throws IOException {\r\n\t\tString line = \"\";\r\n\t\tString splitBy = \",\";\r\n\t\tString path = \".\\\\src\\\\main\\\\java\\\\com\\\\covidProject\\\\covid19\\\\Datasets\\\\Indian Cities Database.csv\";\r\n\t\tHashMap<String, List<String>> state_city = new HashMap<>();\r\n\t\t\r\n\t\ttry {\r\n\t\t\t// parsing a CSV file into BufferedReader class constructor\r\n\t\t\tBufferedReader br = new BufferedReader(new FileReader(path));\r\n\t\t\twhile ((line = br.readLine()) != null) // returns a Boolean value\r\n\t\t\t{\r\n\t\t\t\tString[] info = line.split(splitBy); // use comma as separator\r\n\t\t\t\tString City = info[0].toLowerCase();\r\n\t\t\t\tString State = info[5].toLowerCase();\r\n\r\n\t\t\t\tif (state_city.get(State) == null) {\r\n\t\t\t\t\tList<String> temp_list = new ArrayList<>();\r\n\t\t\t\t\ttemp_list.add(City);\r\n\t\t\t\t\tstate_city.put(State, temp_list);\r\n\t\t\t\t} else {\r\n\t\t\t\t\tList<String> temp_list = state_city.get(State);\r\n\t\t\t\t\ttemp_list.add(City);\r\n\t\t\t\t\tstate_city.put(State, temp_list);\r\n\t\t\t\t}\r\n\t\t\t}\r\n\r\n\t\t\tList<Document> list = new ArrayList<Document>();\r\n\t\t\t\r\n\t\t\t//Initialize country\r\n\t\t\tCovidCountry countryDoc = new CovidCountry();\r\n\t\t\tcountryDoc.setName(\"India\");\r\n\t\t\t\r\n\t\t\t//Initialize state list\r\n\t\t\tList<CovidState> states_list = new ArrayList<>();\r\n\t\t\t\r\n\t\t\tfor (Map.Entry<String, List<String>> entry : state_city.entrySet()) {\r\n\t\t\t\t\r\n\t\t\t\t//get state and cities from the map we created \r\n\t\t\t\tString state = entry.getKey();\r\n\t\t\t\tList<String> cities = entry.getValue();\r\n\r\n\t\t\t\tList<CovidSubCity> city_list = new ArrayList<>();\r\n\r\n\t\t\t\t//Cities are created before states.\r\n\t\t\t\tfor (String city : cities) {\r\n\t\t\t\t\tCovidCity covidCity = new CovidCity(city,state,countryDoc.getName());\r\n\t\t\t\t\tthis.covidCityRepository.save(covidCity);\r\n\t\t\t\t\tCovidSubCity subCity = new CovidSubCity(city,covidCity.getId());\r\n\t\t\t\t\tcity_list.add(subCity);\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\t\r\n\t\t\t\t//create state\r\n\t\t\t\tCovidState covidState = new CovidState(state,city_list);\r\n\t\t\t\t//this.covidStateRepository.save(covidState);\r\n\t\t\t\r\n\t\t\t\t\r\n\t\t\t\tstates_list.add(covidState);\r\n\t\t\t\t\r\n\t\t\t}\r\n\t\t\tcountryDoc.setStates(states_list);\r\n\t\t\tthis.covidCountryRepository.save(countryDoc);\r\n\t\t\t\r\n\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\r\n\t}", "public static String getWoeid(String city)\n {\n try {\n String inline = useAPI(\"https://www.metaweather.com/api/location/search/?query=\" + city);\n if (!inline.equals(\"[]\")) {\n String[] words = inline.split(\",\");\n String[] erg = words[2].split(\":\");\n return erg[1];\n }\n } catch (IOException e) {\n e.printStackTrace();\n }\n return null;\n }", "public String getCity() {\n return city;\n }", "@Test\n\t@Title(\"TC_008: Verify that the current weather data is returned correctly when user search for the City Name\")\n\t \n\tpublic void TC_008_Verify_CurrentWeatherInfo_Is_Returned_For_ValidCity() {\n\t\t\n\t\tLocation city = new Location();\n\t\t\n\t\tcity = DataReader.RetrieveLocationFromFile(\"data.json\").get(0);\n\t\t\n\t\tcity.weather = new Weather(\"C\");\n\t\t\n\t\t//Steps:\n\t\t//1. Access to the site\n\t\tendUser.access_Site();\n\t\t\n\t\t//Search Weather by CityName\n\t\tendUser.SearchWeatherbyCityName(city);\n\t\t\n\t\t//Assume that the test application is triggering the correct API as expectation: OncCall\n\t\tcity = endUser.getWeatherInfoViaAPIResponse(city);\n\t\t\n\t\t//Validate Current Weather\n\t\tendUser.Validate_CurrentWeather(city);\n\t\t\n\t\tAssert.assertTrue(TestConfigs.glb_TCFailedMessage, TestConfigs.glb_TCStatus);\n\t}", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "public WeatherForecast getForecast(String city) throws WeatherForecastClientException {\n HttpResponse<String> response;\n try {\n URI uri = new URI(\"http\", \"api.openweathermap.org\", \"/data/2.5/weather\",\n String.format(\"q=%s&units=metric&lang=bg&appid=%s\", city, apiKey), null);\n\n System.out.println(uri);\n HttpRequest request = HttpRequest.newBuilder().uri(uri).build();\n response = weatherHttpClient.send(request, HttpResponse.BodyHandlers.ofString());\n\n } catch (URISyntaxException | IOException | InterruptedException e) {\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\", e);\n }\n if (response.statusCode() == HttpURLConnection.HTTP_OK) {\n Gson gson = new Gson();\n return gson.fromJson(response.body(), WeatherForecast.class);\n } else if (response.statusCode() == HttpURLConnection.HTTP_NOT_FOUND) {\n throw new LocationNotFoundException(\"Couldn't find location with name : \" + city);\n }\n\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\");\n }", "public void saveSearchedCityNames(){\n SharedPreferences.Editor editor = getSharedPreferences(SharedPrefKeys.HISTORY, MODE_PRIVATE).edit();\n Set<String> cityNamesSet = new HashSet<>();\n cityNamesSet.addAll(mSearchedCities);\n editor.putStringSet(\"SearchedCities\", cityNamesSet);\n editor.apply();\n }" ]
[ "0.72435886", "0.7173706", "0.6661717", "0.6646004", "0.6625698", "0.6596086", "0.642264", "0.64055574", "0.6383613", "0.63506174", "0.63252354", "0.6324899", "0.6308754", "0.63063264", "0.62746483", "0.6158591", "0.6153331", "0.61526", "0.6139434", "0.6124415", "0.6124415", "0.6124415", "0.6124415", "0.6124415", "0.6124415", "0.61141014", "0.60994154", "0.60994154", "0.60909307", "0.60879874", "0.6080652", "0.6060738", "0.60558015", "0.60535073", "0.6046975", "0.6046371", "0.60316235", "0.60226476", "0.60226476", "0.6014004", "0.6009113", "0.60044545", "0.60044545", "0.60044545", "0.60044545", "0.5995026", "0.5978997", "0.59270716", "0.59255946", "0.59118426", "0.59064066", "0.589995", "0.58759546", "0.58744216", "0.58652097", "0.58652097", "0.58404607", "0.5834205", "0.5831899", "0.58278346", "0.5827804", "0.5825997", "0.58245075", "0.58041847", "0.57944983", "0.5791389", "0.57732236", "0.5772744", "0.5767124", "0.5766558", "0.5729717", "0.5722237", "0.5707971", "0.5707409", "0.5703148", "0.5697757", "0.5690616", "0.5690616", "0.5690616", "0.5689699", "0.5686655", "0.5681088", "0.5664404", "0.56618536", "0.566185", "0.5657755", "0.5657755", "0.5656197", "0.5655173", "0.5655091", "0.56499934", "0.5640495", "0.56394446", "0.5637115", "0.5631053", "0.56236905", "0.56236905", "0.56236905", "0.56221473", "0.5620722" ]
0.66185427
5
Get Current weather data by city name
@Test(priority = 3) public void verify_Weather_Data_Appears_OnSearching_By_City() { weatherResponse_city = WeatherAPI.getWeatherInfo(ReadWrite.getProperty("Noida_City"), ConfigFileReader.getProperty("appid"), 200); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void getWeather(String city, String units);", "void handleWeatherDataForCity(String cityName);", "@Override\n\tpublic String getWeatherDataCity(String city, String country) throws IOException {\n\n\t\treturn connectAPICity(city, country);\n\t\t\n\t}", "@Override\n public City getStatsByCity(String name) throws UnirestException {\n City cityWeather = new City();\n JSONObject object = weatherService.getWeatherByCity(name);\n Coord coord = formatObject(\"coord\",object,Coord.class);\n Wind wind = formatObject(\"wind\",object,Wind.class);\n\n Clouds clouds = formatObject(\"clouds\",object,Clouds.class);\n MainStats mainStats = formatObject(\"main\",object,MainStats.class);\n JSONObject objectWeather = object.getJSONArray(\"weather\").getJSONObject(0);\n Weather weather = mapWeather(objectWeather);\n cityWeather.setCoord(coord);\n cityWeather.setWeather(weather);\n cityWeather.setWind(wind);\n cityWeather.setClouds(clouds);\n cityWeather.setName(object.getString(\"name\"));\n cityWeather.setTimezone(object.getInt(\"timezone\"));\n cityWeather.setCod(object.getInt(\"cod\"));\n cityWeather.setVisibility(object.getInt(\"visibility\"));\n return cityWeather;\n }", "@GET(\"https://api.openweathermap.org/data/2.5/weather?\")\n Call<WeatherResponse> getWeatherData(@Query(\"q\") String city, @Query(\"appid\") String apiID, @Query(\"units\") String units);", "GeneralWeatherReport queryWeatherReport(String cityId);", "public void getCityData(String cityName){\n\t\tICityDataService cityDataService = new CityDataService();\n\t\tcityData = cityDataService.getCityData(cityName);\n\t}", "public void getCityResult() {\n String cityNameStr = TextUtils.isEmpty(cityName) ? \"Halifax\" : cityName;\n final String url = \"http://api.openweathermap.org/data/2.5/weather?q=\" + cityNameStr + \"&appid=\" + API_KEY + \"&units=\" + CELSIUS_UNITS;\n //build the request\n JsonObjectRequest request = new JsonObjectRequest(\n Request.Method.GET, url, null, new Response.Listener<JSONObject>() {\n\n @Override\n public void onResponse(JSONObject response) {\n\n try {\n JSONArray weather = response.getJSONArray(\"weather\");\n JSONObject main = response.getJSONObject(\"main\");\n JSONObject cloudsJSON = response.getJSONObject(\"clouds\");\n\n //Set values on layout\n setCityNameOnLayout(response);\n setWeather(weather);\n setTemperature(main);\n setMinMaxTemperature(main);\n setHumidity(main);\n setClouds(cloudsJSON);\n setWeatherIcon((weather.getJSONObject(0)).get(\"icon\").toString());\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n }\n }, new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error) {\n error.printStackTrace();\n\n Toast.makeText(getApplicationContext(), \"Please, introduce an existing city\", Toast.LENGTH_SHORT).show();\n }\n }\n );\n RequestQueueSingleton.getInstance(getApplicationContext()).addToRequestQueue(request);\n }", "@Cacheable(\"weather\")\r\n\tpublic Weather getWeatherByCityAndCountry(String country, String city) {\n\t\tlogger.info(\"Requesting current weather for {}/{}\", country, city);\r\n\t\t\r\n\t\tURI url = new UriTemplate(WEATHER_URL).expand(city, country, this.apiKey);\r\n\t\treturn invoke(url, Weather.class);\r\n\t}", "public WeatherForecast getForecast(String city) throws WeatherForecastClientException {\n HttpResponse<String> response;\n try {\n URI uri = new URI(\"http\", \"api.openweathermap.org\", \"/data/2.5/weather\",\n String.format(\"q=%s&units=metric&lang=bg&appid=%s\", city, apiKey), null);\n\n System.out.println(uri);\n HttpRequest request = HttpRequest.newBuilder().uri(uri).build();\n response = weatherHttpClient.send(request, HttpResponse.BodyHandlers.ofString());\n\n } catch (URISyntaxException | IOException | InterruptedException e) {\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\", e);\n }\n if (response.statusCode() == HttpURLConnection.HTTP_OK) {\n Gson gson = new Gson();\n return gson.fromJson(response.body(), WeatherForecast.class);\n } else if (response.statusCode() == HttpURLConnection.HTTP_NOT_FOUND) {\n throw new LocationNotFoundException(\"Couldn't find location with name : \" + city);\n }\n\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\");\n }", "@Override\n\tpublic String getHourlyWeatherData(String city, String country) throws IOException {\n\t\t\n\t\treturn connectFiveDayForecast(city, country);\n\t\t\n\t}", "private void searchCity() {\n toggleProgress();\n try {\n WeatherClient client = builder.attach(this)\n .provider(new OpenweathermapProviderType())\n .httpClient(WeatherClientDefault.class)\n .config(config)\n .build();\n\n // Try to find a good location\n // using medium settings\n Criteria criteria = new Criteria();\n criteria.setPowerRequirement(Criteria.POWER_MEDIUM);\n criteria.setAccuracy(Criteria.ACCURACY_MEDIUM);\n // Can we use data?\n criteria.setCostAllowed(true);\n\n // Search city by gps/network using\n // above critera\n client.searchCityByLocation(\n criteria,\n new WeatherClient.CityEventListener() {\n\n // When we get the city list\n @Override\n public void onCityListRetrieved(List<City> cityList) {\n for (int i = 0; i < cityList.size(); i++) {\n adapter.set(cityList.get(i), i);\n }\n displayMessage(\"Not the correct results?\" +\n \" Press the button above to try again.\");\n }\n\n\n @Override\n public void onWeatherError(WeatherLibException wle) {\n displayMessage(\"There seems to be no \" +\n \"weather data, please try again later.\");\n\n }\n\n\n @Override\n public void onConnectionError(Throwable t) {\n displayMessage(\"Whoops! We can't seem to \" +\n \"connect to the weather servers.\");\n }\n\n });\n\n } catch (WeatherProviderInstantiationException e) {\n displayMessage(\"Error: Unable to access \" +\n \"the weather provider.\");\n } catch (LocationProviderNotFoundException e) {\n displayMessage(\"Whoops! Unable to access \" +\n \"location provider.\");\n } catch (NullPointerException e) {\n displayMessage(\"Whoops! We can't seem to\" +\n \"connect to the weather servers.\");\n }\n\n }", "public void callAPICall_shouldRetrieveCurrentWeatherInformation(String cityName) {\n\n WeatherAPIManager weatherAPIManager = new WeatherAPIManager(activity);\n weatherAPIManager.setOnResponseListener(new WeatherAPIManagerOnResponseListener());\n weatherAPIManager.connectToWeatherEndpoint(cityName);\n }", "@GET(\"/v3/weather/now.json\")\n Call<City> getCity(@Query(\"key\")String key,@Query(\"location\")String location);", "@GET(\"weather?APPID=bec2ea2f434c848c09196f2de96e3c4c&units=metric\")\n Single<Weather> getWeatherData(@Query(\"q\") String name);", "@SneakyThrows\n String getTemperature(String city) throws MalformedURLException, IOException {\n double current_temperature = 0;\n JSONObject json = new JSONObject(IOUtils.toString(new URL(\"https://api.openweathermap.org/data/2.5/weather?q=\" + city.toLowerCase(Locale.ROOT) + \"&appid=\"), Charset.forName(\"UTF-8\")));\n current_temperature = (Float.parseFloat(json.getJSONObject(\"main\").get(\"temp\").toString()));\n current_temperature = Math.round(current_temperature*100.0)/100.0;\n System.out.println(json);\n return current_temperature + \"\";\n }", "public Weather getDetails(String cityName) throws SQLException, JSONException {\n Weather wSO = weatherService.getWeatherService(cityName);\n List<Cities> citySO = cityRepository.getCityDetails(cityName);\n\n return extractCityDetails(wSO, citySO);\n }", "@RequestMapping(value = \"/weather/{cityName}\", method = RequestMethod.GET)\n public ResponseEntity<Weather> getWeatherDetails(@PathVariable(\"cityName\") String cityName)\n {\n logger.info(\"Calling getWeatherDetails() method with \" + cityName + \" as param\");\n Weather weather = weatherService.getWeather(cityName);\n\n if(weather.getCurrentObservation() == null)\n {\n logger.debug(\"NULL DATA RETURNED\");\n return new ResponseEntity<Weather>(HttpStatus.NOT_FOUND);\n }\n\n return new ResponseEntity<Weather>(weather, HttpStatus.OK);\n }", "public synchronized void getWeeklyForecast(String city){\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"Weekly_Forecast\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\t\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = WEEKLY_FORECAST;\r\n\t\tmsg.obj = \"http://api.wunderground.com/auto/wui/geo/ForecastXML/index.xml?query=\".concat(city);\r\n\t\thandler.sendMessage(msg);\r\n\t}", "private void getWeatherData() {\n System.out.println(\"at getWeather\");\n String url = \"https://api.openweathermap.org/data/2.5/onecall/timemachine?lat=\";\n url += databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LATITUDE);\n url += \"&lon=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LONGITUDE);\n url += \"&dt=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.START_TIME).substring(0, 10);\n url += \"&appid=your openweathermap API key\";\n new ClientThread(ClientThread.GET_WEATHER, new String[]{url, Integer.toString(experimentNumber)}, this).start();\n }", "String[] getRawWeatherData(String city) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + city + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "@Override\n @Cacheable(\"darkSkyFullWeather\")\n public WeatherDataDto getFullWeather(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n weatherDataDto.setPressure(pressure);\n weatherDataDto.setWindSpeed(windSpeed);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "void loadData() {\n Request request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=20.5937,78.9629\")\n .get().build();\n //Create OkHttpClient Object\n OkHttpClient client = new OkHttpClient();\n\n // Call the request using client we just created\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n //Use this code to Handle Failed Request mostly due to internet issue\n // we will just Create a Tost Message for user\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n //Here we will check is reponse is Sucessfull or is their any\n // request error i.e url error\n if (!response.isSuccessful()) {\n //Here our reponse is UnSucessfull so we inform the user\n // about the same as before\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n //If Response is sucessfull we move forward and convert the\n // reponse which is in JSON format to String\n String respFromApi = response.body().string();\n\n //We will Log this LogCat in order to view the Raw Format recieved\n //you can open the log cat go in debug section and type RawData you\n // will be able to observe data there\n Log.d(\"RawData\", respFromApi);\n\n //Now We will call Extract Data Function which will retrieve the\n // woied and name of each city from the response\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n //Informing Data is Not in JSON Format\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n ;\n }\n });\n\n\n //---------------------------------FOR United States----------------------------------------\n\n //Following codes has similar output as before but the difference is the city Names here\n //is of United States\n request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=38.899101,-77.028999\")\n .get().build();\n client = new OkHttpClient();\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n if (!response.isSuccessful()) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n String respFromApi = response.body().string();\n Log.d(\"RawData\", respFromApi);\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n\n\n\n }", "@Cacheable(\"darkSkyTemperature\")\n public WeatherDataDto getTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(getServiceName());\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Test(priority = 2)\n\tpublic void WeatherReportForParticularCity() {\n\t\ttest.homepage.searchForLocation(ReadWrite.getProperty(\"Noida_City_State\"));\n\t\ttest.currentWeatherReportPage.verifyCurrentDayAndTime();\n\t\tweatherMap = test.currentWeatherReportPage.storeInformationOfWeather();\n\n\t}", "@Override\n\t\tprotected GetWeatherRes doInBackground(Void... params) {\n\t\t\treturn JsonOA.getWeatherInfo(cityId, timeStamp);\n\t\t}", "public abstract WeatherData getCurrentWeather(LocationCoordinate _location) throws Exception;", "public static String getWoeid(String city)\n {\n try {\n String inline = useAPI(\"https://www.metaweather.com/api/location/search/?query=\" + city);\n if (!inline.equals(\"[]\")) {\n String[] words = inline.split(\",\");\n String[] erg = words[2].split(\":\");\n return erg[1];\n }\n } catch (IOException e) {\n e.printStackTrace();\n }\n return null;\n }", "String getCity();", "public void getWeatherData(View view){\n InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n imm.hideSoftInputFromWindow(editText.getWindowToken(), 0);\n\n //get city name from user's input in edittext\n String cityText = editText.getText().toString();\n\n //make sure spaces between words is handled properly\n try {\n String spacedCityName= URLEncoder.encode(cityText, \"UTF-8\");\n //concatenated string for link to be opened\n String link = \"https://openweathermap.org/data/2.5/weather?q=\" + spacedCityName + \"&appid=b6907d289e10d714a6e88b30761fae22\";\n //create Download class to download data\n DownloadClass downloadClass = new DownloadClass();\n downloadClass.execute(link);\n }catch (Exception e){\n loadToast();\n e.printStackTrace();\n }\n\n\n\n }", "public List<InputData> getCityData(String city) {\n String SQL = \"SELECT * FROM world_bank WHERE city = ?\";\n List<InputData> records = jdbcTemplate.query(SQL,\n new Object[] { city }, new DataMapper());\n return records;\n }", "public List<WeatherCitySummary> findAllCity(){\n return weatherCityRepository.findAllCity();\n }", "@Override\n protected WeatherInfo doInBackground(Void... params) {\n String weatherID = \"\";\n String areaID = \"\";\n try {\n String cityIds = null;\n if (mRequest.getRequestInfo().getRequestType()\n == RequestInfo.TYPE_WEATHER_BY_WEATHER_LOCATION_REQ) {\n cityIds = mRequest.getRequestInfo().getWeatherLocation().getCityId();\n weatherID = cityIds.split(\",\")[0];\n areaID = cityIds.split(\",\")[1];\n } else if (mRequest.getRequestInfo().getRequestType() ==\n RequestInfo.TYPE_WEATHER_BY_GEO_LOCATION_REQ) {\n double lat = mRequest.getRequestInfo().getLocation().getLatitude();\n double lng = mRequest.getRequestInfo().getLocation().getLongitude();\n\n String cityNameResponse = HttpRetriever.retrieve(String.format(GEO_URL, lat, lng));\n if (TextUtils.isEmpty(cityNameResponse)) {\n return null;\n }\n cityNameResponse = cityNameResponse.replace(\"renderReverse&&renderReverse(\", \"\").replace(\")\", \"\");\n Log.d(TAG, \"cityNameResponse\" + cityNameResponse);\n JSONObject jsonObjectCity = JSON.parseObject(cityNameResponse);\n String areaName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"district\");\n String cityName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"city\");\n areaName = TextUtil.getFormatArea(areaName);\n cityName = TextUtil.getFormatArea(cityName);\n City city = cityDao.getCityByCityAndArea(cityName, areaName);\n if (city == null) {\n city = cityDao.getCityByCityAndArea(cityName, cityName);\n if (city == null)\n return null;\n }\n weatherID = city.getWeatherId();\n areaID = city.getAreaId();\n } else {\n return null;\n }\n\n //miui天气\n String miuiURL = String.format(URL_WEATHER_MIUI, weatherID);\n if (DEBUG) Log.d(TAG, \"miuiURL \" + miuiURL);\n String miuiResponse = HttpRetriever.retrieve(miuiURL);\n if (miuiResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"Rmiuiesponse \" + miuiResponse);\n\n //2345天气\n String ttffUrl = String.format(URL_WEATHER_2345, areaID);\n if (DEBUG) Log.d(TAG, \"ttffUrl \" + ttffUrl);\n String ttffResponse = DecodeUtil.decodeResponse(HttpRetriever.retrieve(ttffUrl));\n if (ttffResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"ttffResponse \" + ttffResponse);\n\n\n JSONObject ttffAll = JSON.parseObject(ttffResponse);\n String cityName = ttffAll.getString(\"cityName\");\n //实时\n JSONObject sk = ttffAll.getJSONObject(\"sk\");\n String humidity = sk.getString(\"humidity\");\n String sk_temp = sk.getString(\"sk_temp\");\n\n //日落日升\n JSONObject sunrise = ttffAll.getJSONObject(\"sunrise\");\n\n ArrayList<WeatherInfo.DayForecast> forecasts =\n parse2345(ttffAll.getJSONArray(\"days7\"), true);\n\n WeatherInfo.Builder weatherInfo = null;\n weatherInfo = new WeatherInfo.Builder(\n cityName, sanitizeTemperature(Double.parseDouble(sk_temp), true),\n WeatherContract.WeatherColumns.TempUnit.CELSIUS);\n //湿度\n humidity = humidity.replace(\"%\", \"\");\n weatherInfo.setHumidity(Double.parseDouble(humidity));\n\n if (miuiResponse != null) {\n //风速,风向\n JSONObject weather = JSON.parseObject(miuiResponse);\n JSONObject accu_cc = weather.getJSONObject(\"accu_cc\");\n weatherInfo.setWind(accu_cc.getDouble(\"WindSpeed\"), accu_cc.getDouble(\"WindDirectionDegrees\"),\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH);\n }\n\n weatherInfo.setTimestamp(System.currentTimeMillis());\n weatherInfo.setForecast(forecasts);\n\n if (forecasts.size() > 0) {\n weatherInfo.setTodaysLow(sanitizeTemperature(forecasts.get(0).getLow(), true));\n weatherInfo.setTodaysHigh(sanitizeTemperature(forecasts.get(0).getHigh(), true));\n weatherInfo.setWeatherCondition(IconUtil.getWeatherCodeByType(\n ttffAll.getJSONArray(\"days7\").getJSONObject(0).getString(\n DateTimeUtil.isNight(sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\"))\n ? \"nightWeaShort\" : \"dayWeaShort\"), sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\")));\n }\n\n if (lastWeatherInfo != null)\n lastWeatherInfo = null;\n\n lastWeatherInfo = weatherInfo.build();\n\n return lastWeatherInfo;\n } catch (Exception e) {\n if (DEBUG) Log.w(TAG, \"JSONException while processing weather update\", e);\n }\n return null;\n }", "@Override\n @Cacheable(\"darkSkyWindSpeed\")\n public WeatherDataDto getWindSpeed(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setWindSpeed(windSpeed);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@GetMapping(\"/getByName/{cityName}\")\n public CityInfo getCityInfoByName(@PathVariable String cityName){\n return service.getByName(cityName);\n }", "public abstract WeatherData[] getDailyWeatherForecast(LocationCoordinate _location) throws Exception;", "public static Weather getNextCityWeather(){\r\n\t\t/*\r\n\t\t * While weatherDetails is getting updated with background\r\n\t\t * Handler, it shouldn't be read\r\n\t\t */\r\n\t\tsynchronized (weatherDetails) {\r\n\t\t\tString code = airportCodes.get(city_index);\r\n\t\t\tLog.i(\"WeatherRecord\", \"Display Weather of: \"+ code+ \" \"+ airportCodes.size());\r\n\t\t\tcity_index++;\r\n\t\t\tif(city_index >= airportCodes.size())\r\n\t\t\t\tcity_index = 0;\r\n\t\t\tWeather w = weatherDetails.get(code);\r\n\t\t\treturn w;\r\n\t\t}\r\n\t}", "@Override\n @Cacheable(\"darkSkyHumidity\")\n public WeatherDataDto getHumidity(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public abstract WeatherData[] getHourlyWeatherForecast(LocationCoordinate _location) throws Exception;", "@GetMapping(\"/weather/current\")\n public Location getCurrentWeather(@RequestParam(value = \"city\", required = false) final String city, @RequestParam(value = \"country\", required = false) final String country, @RequestParam(value = \"lon\", required = false) final String lon, @RequestParam(value = \"lat\", required = false) final String lat) {\n final StringBuilder locationBuilder = new StringBuilder();\n validator.getCurrentWeatherValidator(city, country, lon, lat);\n\n if (city != null) {\n locationBuilder.append(\"city=\").append(city);\n if(country != null) {\n locationBuilder.append(\"&country=\").append(country);\n }\n } else if (lat != null) {\n final double latitude = Double.parseDouble(lat);\n final double longitude = Double.parseDouble(lon);\n final Coordinates latLong = new Coordinates(longitude, latitude);\n locationBuilder.append(latLong.getUriComponent());\n } else {\n Coordinates randomCoordinates = getRandomCoordinates();\n locationBuilder.append(randomCoordinates.getUriComponent());\n }\n\n final String location = locationBuilder.toString();\n return weatherService.getCurrentConditions(location);\n }", "@Override\n @Cacheable(\"darkSkySunriseTime\")\n public WeatherDataDto getSunriseTime(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n String sunrise = \"Api does not support this field.\";\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setSunrise(sunrise);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "private void updateWeatherData(final String city){\n new Thread(){\n public void run(){\n final JSONObject json = WeatherJSON.getJSON(getActivity(), city);\n if(json != null){\n handler.post(new Runnable(){\n public void run(){\n renderWeather(json);\n }\n });\n } else {\n\n }\n }\n }.start();\n }", "java.lang.String getCityName();", "public ArrayList<Flight> getCity(String city) {\n return connects.get(city);\n }", "public static WeatherInfo extractWeather(String response) {\n JsonParser parser = new JsonParser();\n JsonElement jsonElement = parser.parse(response);\n JsonObject rootObject = jsonElement.getAsJsonObject();\n JsonObject location = rootObject.getAsJsonObject(\"location\");\n String city = location.get(\"name\").getAsString();\n String country = location.get(\"country\").getAsString();\n JsonObject current = rootObject.getAsJsonObject(\"current\");\n Double temp = current.get(\"temp_c\").getAsDouble();\n JsonObject condition = current.getAsJsonObject(\"condition\");\n String conditionText = condition.get(\"text\").getAsString();\n return new WeatherInfo(city, country, conditionText, temp);\n}", "@Cacheable(\"darkSkyCityCoordinates\")\n public WeatherDataDto getCityCoordinates(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String latitude = String.valueOf(jsonObject\n .getDouble(\"latitude\"));\n String longitude = String.valueOf(jsonObject\n .getDouble(\"longitude\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setLatitude(latitude);\n weatherDataDto.setLongitude(longitude);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public double getWeatherAPI() {\n\t\tRestAssured.baseURI= props.getProperty(\"BaseURI\");\n\t\tString response = \tgiven().log().all().header(\"Content-Type\",\"application/json\").\n\t\t\t\tqueryParam(\"q\", props.getProperty(\"city\")).\n\t\t\t\tqueryParam(\"appid\", props.getProperty(\"key\")).\n\t\t\t\tqueryParam(\"units\", props.getProperty(\"unit\"))\n\t\t\t\t.when().get(\"data/2.5/weather\")\n\t\t\t\t.then().log().all().assertThat().statusCode(200).header(\"charset\", \"UTF-8\").extract().response().asString();\n\n\n\t\tSystem.out.println(response);\n\n\t\tJsonPath json = new JsonPath(response); // parsing the String response to Json\n\t\tString temp = json.getString(\".main.temp\");\n\t\tSystem.out.println(temp);\n\t\t\n\t\tdouble tempurature = Double.parseDouble(temp);\n\t\t\n\t\treturn tempurature;\n\t\t\n\t\t\n\t\t\n\t}", "@Test\n\t@Title(\"TC_008: Verify that the current weather data is returned correctly when user search for the City Name\")\n\t \n\tpublic void TC_008_Verify_CurrentWeatherInfo_Is_Returned_For_ValidCity() {\n\t\t\n\t\tLocation city = new Location();\n\t\t\n\t\tcity = DataReader.RetrieveLocationFromFile(\"data.json\").get(0);\n\t\t\n\t\tcity.weather = new Weather(\"C\");\n\t\t\n\t\t//Steps:\n\t\t//1. Access to the site\n\t\tendUser.access_Site();\n\t\t\n\t\t//Search Weather by CityName\n\t\tendUser.SearchWeatherbyCityName(city);\n\t\t\n\t\t//Assume that the test application is triggering the correct API as expectation: OncCall\n\t\tcity = endUser.getWeatherInfoViaAPIResponse(city);\n\t\t\n\t\t//Validate Current Weather\n\t\tendUser.Validate_CurrentWeather(city);\n\t\t\n\t\tAssert.assertTrue(TestConfigs.glb_TCFailedMessage, TestConfigs.glb_TCStatus);\n\t}", "net.webservicex.www.WeatherForecasts getWeatherForecasts();", "@Cacheable(\"darkSkyFeelsLikeTemperature\")\n public WeatherDataDto getFeelsLikeTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperatureFeelsLike = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"apparentTemperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperatureFeelsLike(temperatureFeelsLike);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public synchronized void findCity(String cityName){\r\n\t\tLog.v(TAG, \"findCity: \"+ cityName);\r\n\t\tString url = \"http://api.wunderground.com/auto/wui/geo/GeoLookupXML/index.xml?query=\".concat(cityName);\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"City_Search\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = FIND_CITY;\r\n\t\tmsg.obj = url;\r\n\t\thandler.sendMessage(msg);\r\n\t}", "Weather getById(Long id);", "private String connectAPICity(String city, String country) throws IOException {\n\t\t\n\t\tOkHttpClient client = new OkHttpClient();\n\t\tRequest request;\n\t\t\n\t\tif(country.isEmpty()) {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}else {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city + \"%2C\" + country)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}\n\n\t\treturn getResponse(client, request);\n\t\t\n\t}", "public String getCurrentWeather() {\n\t\tString jsonStr = null;\n\t\t\n\t\tClient client = ClientBuilder.newClient();\t\t\n\t\tWebTarget target = client.target(OpenWeatherApiUtil.BASE_URL)\n\t\t\t\t.path(OpenWeatherApiUtil.WEATHER_RESOURCE)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.CITY_QUERY_PARAM, CITY_VANCOUVER)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.UNITS_QUERY_PARAM, OpenWeatherApiUtil.METRIC_UNITS)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.API_KEY_QUERY_PARAM, getApiKey());\n\n\t\tLOG.debug(\"Target URL: \" + target.getUri().toString());\n\t\t\n\t\tInvocation.Builder invocationBuilder = target.request(MediaType.APPLICATION_JSON);\t\t\n\t\t\n\t\tResponse response = invocationBuilder.get(Response.class);\t\t\n\t\tjsonStr = response.readEntity(String.class);\n\t\t\n\t\t// Check response from Open Weather API and log the response appropriately\n\t\tif (response.getStatus() == 200) {\n\t\t\tLOG.debug(jsonStr);\n\t\t}\n\t\telse {\n\t\t\tLOG.error(ErrorMessageUtils.ERROR_OPEN_WEATHER_API_RESPONSE_NON_200_STATUS\n\t\t\t\t\t+ \"\\n\" + response.readEntity(String.class));\n\t\t}\n\t\t\t\n\t\treturn jsonStr;\n\t}", "public String getCity() {\n return (String) get(\"city\");\n }", "public static String getCityWeatherInfos(float latitude, float longitude) {\n\t\tString urlString = \"https://api.openweathermap.org/data/2.5/weather?lat=\" + latitude \n\t\t\t\t+ \"&lon=\" + longitude + \"&appid=\" + API_KEY;\n\t\t\n\t\tStringBuilder result = new StringBuilder();\n\t\t\n\t\ttry {\n\t\t\tURL url = new URL(urlString);\n\t\t\tURLConnection conn = url.openConnection();\n\t\t\t\n\t\t\tBufferedReader rd = new BufferedReader(new InputStreamReader(conn.getInputStream()));\n\t\t\tString line;\n\t\t\t\n\t\t\twhile ((line = rd.readLine()) != null) {\n\t\t\t\tresult.append(line);\n\t\t\t}\n\t\t\t\n\t\t\trd.close();\n\t\t\tSystem.out.println(result);\n\t\t} catch (Exception e) {\n\t\t\tSystem.out.println(e.getMessage());\n\t\t\t// TODO: handle exception\n\t\t}\t\n\t\t\tString weatherInfos = result.toString();\n\t\t\t\n\t\t\treturn weatherInfos;\n\t}", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "@Override\n public rx.Observable<CityWeather> getForecast(final String cityId) {\n return Observable.create(new Observable.OnSubscribe<CityWeather>() {\n @Override\n public void call(Subscriber<? super CityWeather> subscriber) {\n try {\n subscriber.onNext(getCityWeatherFromCityId(cityId));\n } catch (Exception e) {\n subscriber.onError(e);\n } finally {\n subscriber.onCompleted();\n }\n }\n });\n }", "public void downloadWeatherForCurrentLocation() {\n if(checkConnection()) {\n LocationManager locationManager = LocationManager.getInstance(this, view);\n locationManager.getCoordinates();\n } else {\n showNoConnectionDialog();\n }\n }", "public String getCity()\n {\n \treturn city;\n }", "public static void getJsonCity(String cityName, RequestQueue rq, final WeatherClientListener listener) {\n String cityQuery = makeQueryForJsonCity(cityName);\n Log.d(\"getJsonCity\", \"getCity: Weather URL [\"+cityQuery+\"]\");\n// final CityResult result = new CityResult();\n StringRequest req = new StringRequest(Request.Method.GET, cityQuery, new Response.Listener<String>() {\n @Override\n public void onResponse(String response) {\n Log.d(\"JsonCityResponse\", response);\n CityResult result = parseJsonCityResponse(response);\n\n Log.d(\"JsonCityResult\", result.toString());\n listener.onCityResponse(result);\n }\n }, new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError volleyError) {\n Log.d(\"getJsonCity\", \"error\");\n }\n });\n rq.add(req);\n }", "private static boolean fetchYahooWeather() {\n try {\n SAXParserFactory spf = SAXParserFactory.newInstance();\n spf.setNamespaceAware(true);\n SAXParser parser = spf.newSAXParser();\n \n String yql_format = String.format(\"select %%s from %%s where woeid in (select woeid from geo.places(1) where text=\\\"%s, %s\\\")\", CITY, ST);\n \n /* Fetch Wind Data (temp, windDir, and windSpeed) */\n String yql_wind = String.format(yql_format, \"wind\", \"weather.forecast\");\n String url_wind = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_wind, \"UTF-8\"));\n \n DefaultHandler wind_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:wind\")) return;\n \n temp = Integer.parseInt(attributes.getValue(\"chill\"));\n \n int dir = Integer.parseInt(attributes.getValue(\"direction\")); // number from 0-359 indicating direction\n // I began writing an if tree, then remembered I was lazy.\n String[] dir_words = new String[] {\n \"east\", \"northeast\", \"north\", \"northwest\", \"west\", \"southwest\", \"south\", \"southeast\"\n };\n windDir = dir_words[dir/45];\n \n windSpeed = Integer.parseInt(attributes.getValue(\"speed\")); // speed in mph\n }\n };\n parser.parse(url_wind, wind_handler);\n \n /* Fetch Atronomy Data (sunriseHour and sunsetHour) */\n String yql_astro = String.format(yql_format, \"astronomy\", \"weather.forecast\");\n String url_astro = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_astro, \"UTF-8\"));\n \n DefaultHandler astro_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:astronomy\")) return;\n \n sunriseHour = Util.parseTime(attributes.getValue(\"sunrise\"));\n sunsetHour = Util.parseTime(attributes.getValue(\"sunset\"));\n \n }\n };\n parser.parse(url_astro, astro_handler);\n \n /* Fetch Description Data (sky) */\n String yql_sky = String.format(yql_format, \"item.condition.text\", \"weather.forecast\");\n String url_sky = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_sky, \"UTF-8\"));\n \n DefaultHandler sky_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:condition\")) return;\n \n sky = attributes.getValue(\"text\").toLowerCase();\n \n }\n };\n parser.parse(url_sky, sky_handler);\n \n return E.sky != null;\n \n } catch (java.net.UnknownHostException uhe) {\n if (Data.DEBUG) System.err.println(\"You are offline!\");\n return false;\n } catch (Exception e) {\n e.printStackTrace();\n return false;\n }\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\r\n\t\treturn city;\r\n\t}", "public String getCity() {\r\n\t\treturn city;\r\n\t}", "void handleWeatherDataForLocation(String lon, String lat);", "public String getCity() {\n return city;\n }", "public String getCity() {\r\n\t\treturn city;\t\t\r\n\t}", "public WeatherDataResponse getWeather() {\n\n return weather.get(0);\n }", "public static ArrayList<Double> getWebTempValues(String city) {\n try {\n return readDoubleDataInJsonFile(getPropertyValue(\"webdata\"), \"$..\" + city.toLowerCase());\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "public String getCity() \n\t{\n\t\treturn city;\n\t}", "private void getHttpResponse() {\n String url = \"https://api.openweathermap.org/data/2.5/weather?id=\"+city.getId()+\"&units=metric&appid=77078c41435ef3379462eb28afbdf417\";\n\n Request request = new Request.Builder()\n .url(url)\n .header(\"Accept\", \"application/json\")\n .header(\"Content-Type\", \"application/json\")\n .build();\n\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Call call, IOException e) {\n String message = e.getMessage();\n System.out.println(message);\n }\n\n /**\n * Update the UI with the information\n * @param call\n * @param response\n * @throws IOException\n */\n @Override\n public void onResponse(Call call, Response response) throws IOException {\n String body = response.body().string();\n\n Gson gson = new Gson();\n CityInfoDto cityInfo = gson.fromJson(body, CityInfoDto.class);\n\n setNewValues(Math.round(cityInfo.main.temp), cityInfo.weather[0].main);\n setBackground();\n }\n });\n }", "@Cacheable(\"darkSkyWeatherDescription\")\n public WeatherDataDto getWeatherDescription(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setName(city);\n weatherDataDto.setWeatherDescription(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "@Override\n @Cacheable(\"darkSkyPressure\")\n public WeatherDataDto getPressure(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setPressure(pressure);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public String getCity()\n\t{\n\t\treturn city;\n\t}", "public WeatherData (Long sunset, Long sunrise, int weatherCode, String cityName, int temperature) {\n sunsetTime = sunset;\n sunriseTime = sunrise;\n weather = weatherCode;\n city = cityName;\n temp = temperature;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity() {\n return city;\n }", "public String getCity()\r\n\t{\r\n\t\treturn city.getModelObjectAsString();\r\n\t}", "public String getCityname() {\n return cityname;\n }", "@Override\n protected String[] doInBackground(String... params) {\n\n /* If there's no zip code, there's nothing to look up. */\n if (params.length == 0) {\n return null;\n }\n\n String location = params[0];\n URL weatherRequestUrl = NetworkUtils.buildUrl(location);\n\n try {\n String jsonWeatherResponse = NetworkUtils\n .getResponseFromHttpUrl(weatherRequestUrl);\n\n String[] simpleJsonWeatherData = OpenWeatherJsonUtils\n .getSimpleWeatherStringsFromJson(MainActivity.this, jsonWeatherResponse);\n\n return simpleJsonWeatherData;\n\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "public java.lang.String getCity() {\r\n return city;\r\n }", "@Cacheable(\"darkSkyDirectionWind\")\n public WeatherDataDto getDirectionWind(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setDirectionWind(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public java.lang.String getCity () {\n\t\treturn city;\n\t}", "public String getCity() {\n\t\treturn city;\n\t}", "public String getCity() {\n\t\treturn city;\n\t}", "public String getCity() {\n\t\treturn city;\n\t}" ]
[ "0.81723446", "0.7909896", "0.7812095", "0.74907434", "0.7426668", "0.7338908", "0.73169106", "0.7272145", "0.72393364", "0.7196007", "0.71800804", "0.7028804", "0.70177436", "0.7015512", "0.69867045", "0.69745624", "0.6972801", "0.69119024", "0.6852792", "0.68501043", "0.6849738", "0.68159693", "0.67802155", "0.6738614", "0.67007416", "0.66976774", "0.66752636", "0.6647137", "0.6640343", "0.6601834", "0.6596379", "0.6583272", "0.6577938", "0.65741616", "0.65245056", "0.65080404", "0.6506099", "0.64953554", "0.6477518", "0.64502823", "0.64428824", "0.64055544", "0.6404207", "0.639071", "0.63804466", "0.6374778", "0.6329075", "0.6308554", "0.6302436", "0.6299811", "0.6291271", "0.6271223", "0.62671673", "0.6264781", "0.62534773", "0.62201846", "0.6217255", "0.6217255", "0.6217255", "0.621018", "0.6208225", "0.6193164", "0.61907965", "0.61906135", "0.61892223", "0.61859083", "0.61859083", "0.61831915", "0.61756253", "0.61741143", "0.6168802", "0.6163753", "0.6160045", "0.6157936", "0.61524403", "0.61492604", "0.61492604", "0.61492604", "0.6142763", "0.613783", "0.6137153", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.6126544", "0.61188555", "0.6110574", "0.6108968", "0.6108185", "0.61070377", "0.6105163", "0.60969627", "0.60969627", "0.60969627" ]
0.6636371
29
Get Current weather data by city name And State Code
@Test(priority = 4) public void verify_Weather_Data_Appears_OnSearching_By_CityAndStateCode() { WeatherAPI.getWeatherInfo(ReadWrite.getProperty("London_City_State"), ConfigFileReader.getProperty("appid"), 200); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void getWeather(String city, String units);", "void handleWeatherDataForCity(String cityName);", "@Override\n\tpublic String getWeatherDataCity(String city, String country) throws IOException {\n\n\t\treturn connectAPICity(city, country);\n\t\t\n\t}", "@GET(\"https://api.openweathermap.org/data/2.5/weather?\")\n Call<WeatherResponse> getWeatherData(@Query(\"q\") String city, @Query(\"appid\") String apiID, @Query(\"units\") String units);", "GeneralWeatherReport queryWeatherReport(String cityId);", "private void searchCity() {\n toggleProgress();\n try {\n WeatherClient client = builder.attach(this)\n .provider(new OpenweathermapProviderType())\n .httpClient(WeatherClientDefault.class)\n .config(config)\n .build();\n\n // Try to find a good location\n // using medium settings\n Criteria criteria = new Criteria();\n criteria.setPowerRequirement(Criteria.POWER_MEDIUM);\n criteria.setAccuracy(Criteria.ACCURACY_MEDIUM);\n // Can we use data?\n criteria.setCostAllowed(true);\n\n // Search city by gps/network using\n // above critera\n client.searchCityByLocation(\n criteria,\n new WeatherClient.CityEventListener() {\n\n // When we get the city list\n @Override\n public void onCityListRetrieved(List<City> cityList) {\n for (int i = 0; i < cityList.size(); i++) {\n adapter.set(cityList.get(i), i);\n }\n displayMessage(\"Not the correct results?\" +\n \" Press the button above to try again.\");\n }\n\n\n @Override\n public void onWeatherError(WeatherLibException wle) {\n displayMessage(\"There seems to be no \" +\n \"weather data, please try again later.\");\n\n }\n\n\n @Override\n public void onConnectionError(Throwable t) {\n displayMessage(\"Whoops! We can't seem to \" +\n \"connect to the weather servers.\");\n }\n\n });\n\n } catch (WeatherProviderInstantiationException e) {\n displayMessage(\"Error: Unable to access \" +\n \"the weather provider.\");\n } catch (LocationProviderNotFoundException e) {\n displayMessage(\"Whoops! Unable to access \" +\n \"location provider.\");\n } catch (NullPointerException e) {\n displayMessage(\"Whoops! We can't seem to\" +\n \"connect to the weather servers.\");\n }\n\n }", "@Test(priority = 2)\n\tpublic void WeatherReportForParticularCity() {\n\t\ttest.homepage.searchForLocation(ReadWrite.getProperty(\"Noida_City_State\"));\n\t\ttest.currentWeatherReportPage.verifyCurrentDayAndTime();\n\t\tweatherMap = test.currentWeatherReportPage.storeInformationOfWeather();\n\n\t}", "void loadData() {\n Request request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=20.5937,78.9629\")\n .get().build();\n //Create OkHttpClient Object\n OkHttpClient client = new OkHttpClient();\n\n // Call the request using client we just created\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n //Use this code to Handle Failed Request mostly due to internet issue\n // we will just Create a Tost Message for user\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n //Here we will check is reponse is Sucessfull or is their any\n // request error i.e url error\n if (!response.isSuccessful()) {\n //Here our reponse is UnSucessfull so we inform the user\n // about the same as before\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n //If Response is sucessfull we move forward and convert the\n // reponse which is in JSON format to String\n String respFromApi = response.body().string();\n\n //We will Log this LogCat in order to view the Raw Format recieved\n //you can open the log cat go in debug section and type RawData you\n // will be able to observe data there\n Log.d(\"RawData\", respFromApi);\n\n //Now We will call Extract Data Function which will retrieve the\n // woied and name of each city from the response\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n //Informing Data is Not in JSON Format\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n ;\n }\n });\n\n\n //---------------------------------FOR United States----------------------------------------\n\n //Following codes has similar output as before but the difference is the city Names here\n //is of United States\n request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=38.899101,-77.028999\")\n .get().build();\n client = new OkHttpClient();\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n if (!response.isSuccessful()) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n String respFromApi = response.body().string();\n Log.d(\"RawData\", respFromApi);\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n\n\n\n }", "@GET(\"/v3/weather/now.json\")\n Call<City> getCity(@Query(\"key\")String key,@Query(\"location\")String location);", "public void getCityData(String cityName){\n\t\tICityDataService cityDataService = new CityDataService();\n\t\tcityData = cityDataService.getCityData(cityName);\n\t}", "@Override\n\tpublic String getHourlyWeatherData(String city, String country) throws IOException {\n\t\t\n\t\treturn connectFiveDayForecast(city, country);\n\t\t\n\t}", "@Test(priority = 3)\n\tpublic void verify_Weather_Data_Appears_OnSearching_By_City() {\n\t\tweatherResponse_city = WeatherAPI.getWeatherInfo(ReadWrite.getProperty(\"Noida_City\"),\n\t\t\t\tConfigFileReader.getProperty(\"appid\"), 200);\n\n\t}", "private void getWeatherData() {\n System.out.println(\"at getWeather\");\n String url = \"https://api.openweathermap.org/data/2.5/onecall/timemachine?lat=\";\n url += databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LATITUDE);\n url += \"&lon=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LONGITUDE);\n url += \"&dt=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.START_TIME).substring(0, 10);\n url += \"&appid=your openweathermap API key\";\n new ClientThread(ClientThread.GET_WEATHER, new String[]{url, Integer.toString(experimentNumber)}, this).start();\n }", "@Override\n public City getStatsByCity(String name) throws UnirestException {\n City cityWeather = new City();\n JSONObject object = weatherService.getWeatherByCity(name);\n Coord coord = formatObject(\"coord\",object,Coord.class);\n Wind wind = formatObject(\"wind\",object,Wind.class);\n\n Clouds clouds = formatObject(\"clouds\",object,Clouds.class);\n MainStats mainStats = formatObject(\"main\",object,MainStats.class);\n JSONObject objectWeather = object.getJSONArray(\"weather\").getJSONObject(0);\n Weather weather = mapWeather(objectWeather);\n cityWeather.setCoord(coord);\n cityWeather.setWeather(weather);\n cityWeather.setWind(wind);\n cityWeather.setClouds(clouds);\n cityWeather.setName(object.getString(\"name\"));\n cityWeather.setTimezone(object.getInt(\"timezone\"));\n cityWeather.setCod(object.getInt(\"cod\"));\n cityWeather.setVisibility(object.getInt(\"visibility\"));\n return cityWeather;\n }", "public abstract WeatherData getCurrentWeather(LocationCoordinate _location) throws Exception;", "public WeatherForecast getForecast(String city) throws WeatherForecastClientException {\n HttpResponse<String> response;\n try {\n URI uri = new URI(\"http\", \"api.openweathermap.org\", \"/data/2.5/weather\",\n String.format(\"q=%s&units=metric&lang=bg&appid=%s\", city, apiKey), null);\n\n System.out.println(uri);\n HttpRequest request = HttpRequest.newBuilder().uri(uri).build();\n response = weatherHttpClient.send(request, HttpResponse.BodyHandlers.ofString());\n\n } catch (URISyntaxException | IOException | InterruptedException e) {\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\", e);\n }\n if (response.statusCode() == HttpURLConnection.HTTP_OK) {\n Gson gson = new Gson();\n return gson.fromJson(response.body(), WeatherForecast.class);\n } else if (response.statusCode() == HttpURLConnection.HTTP_NOT_FOUND) {\n throw new LocationNotFoundException(\"Couldn't find location with name : \" + city);\n }\n\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\");\n }", "@Cacheable(\"weather\")\r\n\tpublic Weather getWeatherByCityAndCountry(String country, String city) {\n\t\tlogger.info(\"Requesting current weather for {}/{}\", country, city);\r\n\t\t\r\n\t\tURI url = new UriTemplate(WEATHER_URL).expand(city, country, this.apiKey);\r\n\t\treturn invoke(url, Weather.class);\r\n\t}", "@Override\n @Cacheable(\"darkSkyFullWeather\")\n public WeatherDataDto getFullWeather(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n weatherDataDto.setPressure(pressure);\n weatherDataDto.setWindSpeed(windSpeed);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public void getCityResult() {\n String cityNameStr = TextUtils.isEmpty(cityName) ? \"Halifax\" : cityName;\n final String url = \"http://api.openweathermap.org/data/2.5/weather?q=\" + cityNameStr + \"&appid=\" + API_KEY + \"&units=\" + CELSIUS_UNITS;\n //build the request\n JsonObjectRequest request = new JsonObjectRequest(\n Request.Method.GET, url, null, new Response.Listener<JSONObject>() {\n\n @Override\n public void onResponse(JSONObject response) {\n\n try {\n JSONArray weather = response.getJSONArray(\"weather\");\n JSONObject main = response.getJSONObject(\"main\");\n JSONObject cloudsJSON = response.getJSONObject(\"clouds\");\n\n //Set values on layout\n setCityNameOnLayout(response);\n setWeather(weather);\n setTemperature(main);\n setMinMaxTemperature(main);\n setHumidity(main);\n setClouds(cloudsJSON);\n setWeatherIcon((weather.getJSONObject(0)).get(\"icon\").toString());\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n }\n }, new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error) {\n error.printStackTrace();\n\n Toast.makeText(getApplicationContext(), \"Please, introduce an existing city\", Toast.LENGTH_SHORT).show();\n }\n }\n );\n RequestQueueSingleton.getInstance(getApplicationContext()).addToRequestQueue(request);\n }", "@Override\n protected WeatherInfo doInBackground(Void... params) {\n String weatherID = \"\";\n String areaID = \"\";\n try {\n String cityIds = null;\n if (mRequest.getRequestInfo().getRequestType()\n == RequestInfo.TYPE_WEATHER_BY_WEATHER_LOCATION_REQ) {\n cityIds = mRequest.getRequestInfo().getWeatherLocation().getCityId();\n weatherID = cityIds.split(\",\")[0];\n areaID = cityIds.split(\",\")[1];\n } else if (mRequest.getRequestInfo().getRequestType() ==\n RequestInfo.TYPE_WEATHER_BY_GEO_LOCATION_REQ) {\n double lat = mRequest.getRequestInfo().getLocation().getLatitude();\n double lng = mRequest.getRequestInfo().getLocation().getLongitude();\n\n String cityNameResponse = HttpRetriever.retrieve(String.format(GEO_URL, lat, lng));\n if (TextUtils.isEmpty(cityNameResponse)) {\n return null;\n }\n cityNameResponse = cityNameResponse.replace(\"renderReverse&&renderReverse(\", \"\").replace(\")\", \"\");\n Log.d(TAG, \"cityNameResponse\" + cityNameResponse);\n JSONObject jsonObjectCity = JSON.parseObject(cityNameResponse);\n String areaName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"district\");\n String cityName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"city\");\n areaName = TextUtil.getFormatArea(areaName);\n cityName = TextUtil.getFormatArea(cityName);\n City city = cityDao.getCityByCityAndArea(cityName, areaName);\n if (city == null) {\n city = cityDao.getCityByCityAndArea(cityName, cityName);\n if (city == null)\n return null;\n }\n weatherID = city.getWeatherId();\n areaID = city.getAreaId();\n } else {\n return null;\n }\n\n //miui天气\n String miuiURL = String.format(URL_WEATHER_MIUI, weatherID);\n if (DEBUG) Log.d(TAG, \"miuiURL \" + miuiURL);\n String miuiResponse = HttpRetriever.retrieve(miuiURL);\n if (miuiResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"Rmiuiesponse \" + miuiResponse);\n\n //2345天气\n String ttffUrl = String.format(URL_WEATHER_2345, areaID);\n if (DEBUG) Log.d(TAG, \"ttffUrl \" + ttffUrl);\n String ttffResponse = DecodeUtil.decodeResponse(HttpRetriever.retrieve(ttffUrl));\n if (ttffResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"ttffResponse \" + ttffResponse);\n\n\n JSONObject ttffAll = JSON.parseObject(ttffResponse);\n String cityName = ttffAll.getString(\"cityName\");\n //实时\n JSONObject sk = ttffAll.getJSONObject(\"sk\");\n String humidity = sk.getString(\"humidity\");\n String sk_temp = sk.getString(\"sk_temp\");\n\n //日落日升\n JSONObject sunrise = ttffAll.getJSONObject(\"sunrise\");\n\n ArrayList<WeatherInfo.DayForecast> forecasts =\n parse2345(ttffAll.getJSONArray(\"days7\"), true);\n\n WeatherInfo.Builder weatherInfo = null;\n weatherInfo = new WeatherInfo.Builder(\n cityName, sanitizeTemperature(Double.parseDouble(sk_temp), true),\n WeatherContract.WeatherColumns.TempUnit.CELSIUS);\n //湿度\n humidity = humidity.replace(\"%\", \"\");\n weatherInfo.setHumidity(Double.parseDouble(humidity));\n\n if (miuiResponse != null) {\n //风速,风向\n JSONObject weather = JSON.parseObject(miuiResponse);\n JSONObject accu_cc = weather.getJSONObject(\"accu_cc\");\n weatherInfo.setWind(accu_cc.getDouble(\"WindSpeed\"), accu_cc.getDouble(\"WindDirectionDegrees\"),\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH);\n }\n\n weatherInfo.setTimestamp(System.currentTimeMillis());\n weatherInfo.setForecast(forecasts);\n\n if (forecasts.size() > 0) {\n weatherInfo.setTodaysLow(sanitizeTemperature(forecasts.get(0).getLow(), true));\n weatherInfo.setTodaysHigh(sanitizeTemperature(forecasts.get(0).getHigh(), true));\n weatherInfo.setWeatherCondition(IconUtil.getWeatherCodeByType(\n ttffAll.getJSONArray(\"days7\").getJSONObject(0).getString(\n DateTimeUtil.isNight(sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\"))\n ? \"nightWeaShort\" : \"dayWeaShort\"), sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\")));\n }\n\n if (lastWeatherInfo != null)\n lastWeatherInfo = null;\n\n lastWeatherInfo = weatherInfo.build();\n\n return lastWeatherInfo;\n } catch (Exception e) {\n if (DEBUG) Log.w(TAG, \"JSONException while processing weather update\", e);\n }\n return null;\n }", "public static Weather getNextCityWeather(){\r\n\t\t/*\r\n\t\t * While weatherDetails is getting updated with background\r\n\t\t * Handler, it shouldn't be read\r\n\t\t */\r\n\t\tsynchronized (weatherDetails) {\r\n\t\t\tString code = airportCodes.get(city_index);\r\n\t\t\tLog.i(\"WeatherRecord\", \"Display Weather of: \"+ code+ \" \"+ airportCodes.size());\r\n\t\t\tcity_index++;\r\n\t\t\tif(city_index >= airportCodes.size())\r\n\t\t\t\tcity_index = 0;\r\n\t\t\tWeather w = weatherDetails.get(code);\r\n\t\t\treturn w;\r\n\t\t}\r\n\t}", "public abstract WeatherData[] getDailyWeatherForecast(LocationCoordinate _location) throws Exception;", "public Weather getDetails(String cityName) throws SQLException, JSONException {\n Weather wSO = weatherService.getWeatherService(cityName);\n List<Cities> citySO = cityRepository.getCityDetails(cityName);\n\n return extractCityDetails(wSO, citySO);\n }", "@Cacheable(\"darkSkyTemperature\")\n public WeatherDataDto getTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(getServiceName());\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public abstract WeatherData[] getHourlyWeatherForecast(LocationCoordinate _location) throws Exception;", "@Override\n @Cacheable(\"darkSkySunriseTime\")\n public WeatherDataDto getSunriseTime(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n String sunrise = \"Api does not support this field.\";\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setSunrise(sunrise);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "String getCity();", "@Override\n\t\tprotected GetWeatherRes doInBackground(Void... params) {\n\t\t\treturn JsonOA.getWeatherInfo(cityId, timeStamp);\n\t\t}", "@GET(\"weather?APPID=bec2ea2f434c848c09196f2de96e3c4c&units=metric\")\n Single<Weather> getWeatherData(@Query(\"q\") String name);", "@Override\n @Cacheable(\"darkSkyWindSpeed\")\n public WeatherDataDto getWindSpeed(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setWindSpeed(windSpeed);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public WeatherData (Long sunset, Long sunrise, int weatherCode, String cityName, int temperature) {\n sunsetTime = sunset;\n sunriseTime = sunrise;\n weather = weatherCode;\n city = cityName;\n temp = temperature;\n }", "@Cacheable(\"darkSkyCityCoordinates\")\n public WeatherDataDto getCityCoordinates(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String latitude = String.valueOf(jsonObject\n .getDouble(\"latitude\"));\n String longitude = String.valueOf(jsonObject\n .getDouble(\"longitude\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setLatitude(latitude);\n weatherDataDto.setLongitude(longitude);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "String[] getRawWeatherData(String city) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + city + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "public List<WeatherCitySummary> findAllCity(){\n return weatherCityRepository.findAllCity();\n }", "@GET(\"/api/\" + BuildConfig.API_KEY + \"/conditions/hourly10day/q/{zip}.json\")\n Observable<WeatherModel> fetchWeather\n (@Path(\"zip\") String zipCode);", "@Override\n @Cacheable(\"darkSkyHumidity\")\n public WeatherDataDto getHumidity(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Test(priority = 5)\n\tpublic void verify_Weather_Data_Appears_OnSearching_By_City_StateCodeAndCountryCode() {\n\t\tWeatherAPI.getWeatherInfo(ReadWrite.getProperty(\"Noida_City_State_Country\"),\n\t\t\t\tConfigFileReader.getProperty(\"appid\"), 200);\n\n\t}", "public void getWeatherData(View view){\n InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n imm.hideSoftInputFromWindow(editText.getWindowToken(), 0);\n\n //get city name from user's input in edittext\n String cityText = editText.getText().toString();\n\n //make sure spaces between words is handled properly\n try {\n String spacedCityName= URLEncoder.encode(cityText, \"UTF-8\");\n //concatenated string for link to be opened\n String link = \"https://openweathermap.org/data/2.5/weather?q=\" + spacedCityName + \"&appid=b6907d289e10d714a6e88b30761fae22\";\n //create Download class to download data\n DownloadClass downloadClass = new DownloadClass();\n downloadClass.execute(link);\n }catch (Exception e){\n loadToast();\n e.printStackTrace();\n }\n\n\n\n }", "@RequestMapping(value = \"/weather/{cityName}\", method = RequestMethod.GET)\n public ResponseEntity<Weather> getWeatherDetails(@PathVariable(\"cityName\") String cityName)\n {\n logger.info(\"Calling getWeatherDetails() method with \" + cityName + \" as param\");\n Weather weather = weatherService.getWeather(cityName);\n\n if(weather.getCurrentObservation() == null)\n {\n logger.debug(\"NULL DATA RETURNED\");\n return new ResponseEntity<Weather>(HttpStatus.NOT_FOUND);\n }\n\n return new ResponseEntity<Weather>(weather, HttpStatus.OK);\n }", "public void callAPICall_shouldRetrieveCurrentWeatherInformation(String cityName) {\n\n WeatherAPIManager weatherAPIManager = new WeatherAPIManager(activity);\n weatherAPIManager.setOnResponseListener(new WeatherAPIManagerOnResponseListener());\n weatherAPIManager.connectToWeatherEndpoint(cityName);\n }", "java.lang.String getCityName();", "net.webservicex.www.WeatherForecasts getWeatherForecasts();", "@Override\n protected String[] doInBackground(String... params) {\n\n /* If there's no zip code, there's nothing to look up. */\n if (params.length == 0) {\n return null;\n }\n\n String location = params[0];\n URL weatherRequestUrl = NetworkUtils.buildUrl(location);\n\n try {\n String jsonWeatherResponse = NetworkUtils\n .getResponseFromHttpUrl(weatherRequestUrl);\n\n String[] simpleJsonWeatherData = OpenWeatherJsonUtils\n .getSimpleWeatherStringsFromJson(MainActivity.this, jsonWeatherResponse);\n\n return simpleJsonWeatherData;\n\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "public synchronized void getWeeklyForecast(String city){\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"Weekly_Forecast\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\t\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = WEEKLY_FORECAST;\r\n\t\tmsg.obj = \"http://api.wunderground.com/auto/wui/geo/ForecastXML/index.xml?query=\".concat(city);\r\n\t\thandler.sendMessage(msg);\r\n\t}", "@SneakyThrows\n String getTemperature(String city) throws MalformedURLException, IOException {\n double current_temperature = 0;\n JSONObject json = new JSONObject(IOUtils.toString(new URL(\"https://api.openweathermap.org/data/2.5/weather?q=\" + city.toLowerCase(Locale.ROOT) + \"&appid=\"), Charset.forName(\"UTF-8\")));\n current_temperature = (Float.parseFloat(json.getJSONObject(\"main\").get(\"temp\").toString()));\n current_temperature = Math.round(current_temperature*100.0)/100.0;\n System.out.println(json);\n return current_temperature + \"\";\n }", "private List<Tuple> weatherMap(Tuple input) {\n \n Map<String, String> mockLocationService = new HashMap<String, String>();\n mockLocationService.put(\"Harrisburg\", \"PA\");\n mockLocationService.put(\"Pittsburgh\", \"PA\");\n mockLocationService.put(\"Phildelphia\", \"PA\");\n mockLocationService.put(\"Houston\", \"TX\");\n mockLocationService.put(\"SanAntonio\", \"TX\");\n mockLocationService.put(\"Austin\", \"TX\");\n mockLocationService.put(\"Sacramento\", \"CA\");\n mockLocationService.put(\"LosAngeles\", \"CA\");\n mockLocationService.put(\"SanFransico\", \"CA\");\n \n List<Tuple> output = new ArrayList<Tuple>();\n \n String city = input.fst();\n String hiLow = input.snd();\n \n output.add(new Tuple(mockLocationService.get(city), hiLow));\n \n lolligag();\n \n //<state, hi low>\n return output;\n }", "public List<InputData> getCityData(String city) {\n String SQL = \"SELECT * FROM world_bank WHERE city = ?\";\n List<InputData> records = jdbcTemplate.query(SQL,\n new Object[] { city }, new DataMapper());\n return records;\n }", "@Cacheable(\"darkSkyDirectionWind\")\n public WeatherDataDto getDirectionWind(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setDirectionWind(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Cacheable(\"darkSkyWeatherDescription\")\n public WeatherDataDto getWeatherDescription(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setName(city);\n weatherDataDto.setWeatherDescription(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "void handleWeatherDataForLocation(String lon, String lat);", "@Test\n\t@Title(\"TC_008: Verify that the current weather data is returned correctly when user search for the City Name\")\n\t \n\tpublic void TC_008_Verify_CurrentWeatherInfo_Is_Returned_For_ValidCity() {\n\t\t\n\t\tLocation city = new Location();\n\t\t\n\t\tcity = DataReader.RetrieveLocationFromFile(\"data.json\").get(0);\n\t\t\n\t\tcity.weather = new Weather(\"C\");\n\t\t\n\t\t//Steps:\n\t\t//1. Access to the site\n\t\tendUser.access_Site();\n\t\t\n\t\t//Search Weather by CityName\n\t\tendUser.SearchWeatherbyCityName(city);\n\t\t\n\t\t//Assume that the test application is triggering the correct API as expectation: OncCall\n\t\tcity = endUser.getWeatherInfoViaAPIResponse(city);\n\t\t\n\t\t//Validate Current Weather\n\t\tendUser.Validate_CurrentWeather(city);\n\t\t\n\t\tAssert.assertTrue(TestConfigs.glb_TCFailedMessage, TestConfigs.glb_TCStatus);\n\t}", "public static String getWoeid(String city)\n {\n try {\n String inline = useAPI(\"https://www.metaweather.com/api/location/search/?query=\" + city);\n if (!inline.equals(\"[]\")) {\n String[] words = inline.split(\",\");\n String[] erg = words[2].split(\":\");\n return erg[1];\n }\n } catch (IOException e) {\n e.printStackTrace();\n }\n return null;\n }", "public List<City> getCityList(State state);", "public CityDailyWeather(String city, int startYear, int endYear, int stationID){\n\t\tthis.city = city;\n\t\tthis.startYear = startYear;\n\t\tthis.endYear = endYear;\n\t\tthis.stationID = stationID;\n\t}", "private String connectAPICity(String city, String country) throws IOException {\n\t\t\n\t\tOkHttpClient client = new OkHttpClient();\n\t\tRequest request;\n\t\t\n\t\tif(country.isEmpty()) {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}else {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city + \"%2C\" + country)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}\n\n\t\treturn getResponse(client, request);\n\t\t\n\t}", "@Override\n @Cacheable(\"darkSkyPressure\")\n public WeatherDataDto getPressure(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setPressure(pressure);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "private static boolean fetchYahooWeather() {\n try {\n SAXParserFactory spf = SAXParserFactory.newInstance();\n spf.setNamespaceAware(true);\n SAXParser parser = spf.newSAXParser();\n \n String yql_format = String.format(\"select %%s from %%s where woeid in (select woeid from geo.places(1) where text=\\\"%s, %s\\\")\", CITY, ST);\n \n /* Fetch Wind Data (temp, windDir, and windSpeed) */\n String yql_wind = String.format(yql_format, \"wind\", \"weather.forecast\");\n String url_wind = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_wind, \"UTF-8\"));\n \n DefaultHandler wind_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:wind\")) return;\n \n temp = Integer.parseInt(attributes.getValue(\"chill\"));\n \n int dir = Integer.parseInt(attributes.getValue(\"direction\")); // number from 0-359 indicating direction\n // I began writing an if tree, then remembered I was lazy.\n String[] dir_words = new String[] {\n \"east\", \"northeast\", \"north\", \"northwest\", \"west\", \"southwest\", \"south\", \"southeast\"\n };\n windDir = dir_words[dir/45];\n \n windSpeed = Integer.parseInt(attributes.getValue(\"speed\")); // speed in mph\n }\n };\n parser.parse(url_wind, wind_handler);\n \n /* Fetch Atronomy Data (sunriseHour and sunsetHour) */\n String yql_astro = String.format(yql_format, \"astronomy\", \"weather.forecast\");\n String url_astro = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_astro, \"UTF-8\"));\n \n DefaultHandler astro_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:astronomy\")) return;\n \n sunriseHour = Util.parseTime(attributes.getValue(\"sunrise\"));\n sunsetHour = Util.parseTime(attributes.getValue(\"sunset\"));\n \n }\n };\n parser.parse(url_astro, astro_handler);\n \n /* Fetch Description Data (sky) */\n String yql_sky = String.format(yql_format, \"item.condition.text\", \"weather.forecast\");\n String url_sky = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_sky, \"UTF-8\"));\n \n DefaultHandler sky_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:condition\")) return;\n \n sky = attributes.getValue(\"text\").toLowerCase();\n \n }\n };\n parser.parse(url_sky, sky_handler);\n \n return E.sky != null;\n \n } catch (java.net.UnknownHostException uhe) {\n if (Data.DEBUG) System.err.println(\"You are offline!\");\n return false;\n } catch (Exception e) {\n e.printStackTrace();\n return false;\n }\n }", "public static String getCityWeatherInfos(float latitude, float longitude) {\n\t\tString urlString = \"https://api.openweathermap.org/data/2.5/weather?lat=\" + latitude \n\t\t\t\t+ \"&lon=\" + longitude + \"&appid=\" + API_KEY;\n\t\t\n\t\tStringBuilder result = new StringBuilder();\n\t\t\n\t\ttry {\n\t\t\tURL url = new URL(urlString);\n\t\t\tURLConnection conn = url.openConnection();\n\t\t\t\n\t\t\tBufferedReader rd = new BufferedReader(new InputStreamReader(conn.getInputStream()));\n\t\t\tString line;\n\t\t\t\n\t\t\twhile ((line = rd.readLine()) != null) {\n\t\t\t\tresult.append(line);\n\t\t\t}\n\t\t\t\n\t\t\trd.close();\n\t\t\tSystem.out.println(result);\n\t\t} catch (Exception e) {\n\t\t\tSystem.out.println(e.getMessage());\n\t\t\t// TODO: handle exception\n\t\t}\t\n\t\t\tString weatherInfos = result.toString();\n\t\t\t\n\t\t\treturn weatherInfos;\n\t}", "@Cacheable(\"darkSkyFeelsLikeTemperature\")\n public WeatherDataDto getFeelsLikeTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperatureFeelsLike = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"apparentTemperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperatureFeelsLike(temperatureFeelsLike);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public static WeatherInfo extractWeather(String response) {\n JsonParser parser = new JsonParser();\n JsonElement jsonElement = parser.parse(response);\n JsonObject rootObject = jsonElement.getAsJsonObject();\n JsonObject location = rootObject.getAsJsonObject(\"location\");\n String city = location.get(\"name\").getAsString();\n String country = location.get(\"country\").getAsString();\n JsonObject current = rootObject.getAsJsonObject(\"current\");\n Double temp = current.get(\"temp_c\").getAsDouble();\n JsonObject condition = current.getAsJsonObject(\"condition\");\n String conditionText = condition.get(\"text\").getAsString();\n return new WeatherInfo(city, country, conditionText, temp);\n}", "java.lang.String getTransitAirportCity();", "public abstract String getCity();", "@RequestMapping(value = \"/cityDetails\", method = RequestMethod.GET)\n public ResponseEntity<City> getCityDetails()\n {\n logger.info(\"Calling getCityDetails() method\");\n if(city.getCity() != null)\n {\n for (String item: city.getCity()\n ) {\n logger.debug(\"This are the cities \" + item);\n }\n }\n\n return new ResponseEntity<City>(city, HttpStatus.OK);\n }", "@Override\n public rx.Observable<CityWeather> getForecast(final String cityId) {\n return Observable.create(new Observable.OnSubscribe<CityWeather>() {\n @Override\n public void call(Subscriber<? super CityWeather> subscriber) {\n try {\n subscriber.onNext(getCityWeatherFromCityId(cityId));\n } catch (Exception e) {\n subscriber.onError(e);\n } finally {\n subscriber.onCompleted();\n }\n }\n });\n }", "private void getHttpResponse() {\n String url = \"https://api.openweathermap.org/data/2.5/weather?id=\"+city.getId()+\"&units=metric&appid=77078c41435ef3379462eb28afbdf417\";\n\n Request request = new Request.Builder()\n .url(url)\n .header(\"Accept\", \"application/json\")\n .header(\"Content-Type\", \"application/json\")\n .build();\n\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Call call, IOException e) {\n String message = e.getMessage();\n System.out.println(message);\n }\n\n /**\n * Update the UI with the information\n * @param call\n * @param response\n * @throws IOException\n */\n @Override\n public void onResponse(Call call, Response response) throws IOException {\n String body = response.body().string();\n\n Gson gson = new Gson();\n CityInfoDto cityInfo = gson.fromJson(body, CityInfoDto.class);\n\n setNewValues(Math.round(cityInfo.main.temp), cityInfo.weather[0].main);\n setBackground();\n }\n });\n }", "@GetMapping(\"/weather/current\")\n public Location getCurrentWeather(@RequestParam(value = \"city\", required = false) final String city, @RequestParam(value = \"country\", required = false) final String country, @RequestParam(value = \"lon\", required = false) final String lon, @RequestParam(value = \"lat\", required = false) final String lat) {\n final StringBuilder locationBuilder = new StringBuilder();\n validator.getCurrentWeatherValidator(city, country, lon, lat);\n\n if (city != null) {\n locationBuilder.append(\"city=\").append(city);\n if(country != null) {\n locationBuilder.append(\"&country=\").append(country);\n }\n } else if (lat != null) {\n final double latitude = Double.parseDouble(lat);\n final double longitude = Double.parseDouble(lon);\n final Coordinates latLong = new Coordinates(longitude, latitude);\n locationBuilder.append(latLong.getUriComponent());\n } else {\n Coordinates randomCoordinates = getRandomCoordinates();\n locationBuilder.append(randomCoordinates.getUriComponent());\n }\n\n final String location = locationBuilder.toString();\n return weatherService.getCurrentConditions(location);\n }", "public static String getXmlCode(String city) throws UnsupportedEncodingException {\n String requestUrl = \"http://api.map.baidu.com/weather/v1/?district_id=222405&data_type=all&ak=WCvM0jwmAi5N3ZmWmTadIUWjSCBzX4vb\"; //GET请求\n StringBuffer buffer = null;\n try {\n // 建立连接\n URL url = new URL(requestUrl);\n HttpURLConnection httpUrlConn = (HttpURLConnection) url.openConnection();\n httpUrlConn.setDoInput(true);\n httpUrlConn.setRequestMethod(\"GET\");\n // 获取输入流\n InputStream inputStream = httpUrlConn.getInputStream();\n InputStreamReader inputStreamReader = new InputStreamReader(inputStream, \"utf-8\");\n BufferedReader bufferedReader = new BufferedReader(inputStreamReader);\n // 读取返回结果\n buffer = new StringBuffer();\n String str = null;\n while ((str = bufferedReader.readLine()) != null) {\n buffer.append(str);\n }\n\n // 释放资源\n bufferedReader.close();\n inputStreamReader.close();\n inputStream.close();\n httpUrlConn.disconnect();\n } catch (Exception e) {\n e.printStackTrace();\n }\n return buffer.toString();\n }", "public YahooWeatherInformation getResult_Weather_Information(){\n return this.Result_Weather_Information;\n }", "private void updateWeatherData(final String city){\n new Thread(){\n public void run(){\n final JSONObject json = WeatherJSON.getJSON(getActivity(), city);\n if(json != null){\n handler.post(new Runnable(){\n public void run(){\n renderWeather(json);\n }\n });\n } else {\n\n }\n }\n }.start();\n }", "List<MasterZipcode> getByCity(int cityId);", "@GetMapping(\"/getByName/{cityName}\")\n public CityInfo getCityInfoByName(@PathVariable String cityName){\n return service.getByName(cityName);\n }", "private List<WeatherStation> getWeatherStations(){\n List<WeatherStation> weatherStations = new ArrayList<>();\n List<String> weatherStationList = new ArrayList<>();\n weatherStationList.add(Constants.STATION_CODE_ADELAIDE);\n weatherStationList.add(Constants.STATION_CODE_BRISBANE);\n weatherStationList.add(Constants.STATION_CODE_CAIRNS);\n weatherStationList.add(Constants.STATION_CODE_CANBERRA);\n weatherStationList.add(Constants.STATION_CODE_DARWIN);\n weatherStationList.add(Constants.STATION_CODE_GOLD_COAST);\n weatherStationList.add(Constants.STATION_CODE_HOBART);\n weatherStationList.add(Constants.STATION_CODE_MELBOURNE);\n weatherStationList.add(Constants.STATION_CODE_PERTH);\n weatherStationList.add(Constants.STATION_CODE_SYDNEY);\n\n for(String weatherStationCode : weatherStationList){\n weatherStations.add(WeatherStationFactory.getWeatherStation(weatherStationCode));\n }\n return weatherStations;\n }", "public void getCity(){\n }", "Weather getById(Long id);", "public interface IWeatherProvider {\r\n\r\n public CurrentWeather getCurrentCondition(String data) throws WeatherLibException;\r\n\r\n public WeatherForecast getForecastWeather(String data) throws WeatherLibException;\r\n\r\n public List<City> getCityResultList(String data) throws WeatherLibException;\r\n\r\n public WeatherHourForecast getHourForecastWeather(String data) throws WeatherLibException;\r\n\r\n public String getQueryCityURL(String cityNamePattern) throws ApiKeyRequiredException;\r\n\r\n // public String getQueryCurrentWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n // public String getQueryForecastWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n public HistoricalWeather getHistoricalWeather(String data) throws WeatherLibException;\r\n\r\n public String getQueryCityURLByLocation(Location location) throws ApiKeyRequiredException;\r\n\r\n public String getQueryCityURLByCoord(double lon, double lat) throws ApiKeyRequiredException;\r\n\r\n\r\n public void setConfig(WeatherConfig config);\r\n\r\n public void setWeatherCodeProvider(IWeatherCodeProvider codeProvider);\r\n\r\n public String getQueryImageURL(String weatherId) throws ApiKeyRequiredException;\r\n\r\n //public String getQueryHourForecastWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n //public String getQueryHistoricalWeatherURL(String cityId, Date startDate, Date endDate) throws ApiKeyRequiredException;\r\n\r\n public String getQueryLayerURL(String cityId, Params params) throws ApiKeyRequiredException;\r\n\r\n\r\n\r\n public String getQueryCurrentWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryForecastWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryHourForecastWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryHistoricalWeatherURL(WeatherRequest request, Date startDate, Date endDate) throws ApiKeyRequiredException;\r\n\r\n}", "public interface IWeatherDataProvider {\n\n\tpublic WeatherData getWeatherData(Location location);\n\t\n}", "public double getWeatherAPI() {\n\t\tRestAssured.baseURI= props.getProperty(\"BaseURI\");\n\t\tString response = \tgiven().log().all().header(\"Content-Type\",\"application/json\").\n\t\t\t\tqueryParam(\"q\", props.getProperty(\"city\")).\n\t\t\t\tqueryParam(\"appid\", props.getProperty(\"key\")).\n\t\t\t\tqueryParam(\"units\", props.getProperty(\"unit\"))\n\t\t\t\t.when().get(\"data/2.5/weather\")\n\t\t\t\t.then().log().all().assertThat().statusCode(200).header(\"charset\", \"UTF-8\").extract().response().asString();\n\n\n\t\tSystem.out.println(response);\n\n\t\tJsonPath json = new JsonPath(response); // parsing the String response to Json\n\t\tString temp = json.getString(\".main.temp\");\n\t\tSystem.out.println(temp);\n\t\t\n\t\tdouble tempurature = Double.parseDouble(temp);\n\t\t\n\t\treturn tempurature;\n\t\t\n\t\t\n\t\t\n\t}", "@Override\n \t\tprotected Void doInBackground(Void... params) {\n \t\t\tgetJSONFromUrl(fore_city,fore_country);\n\n \t\t\treturn null;\n \t\t}", "public String getCurrentWeather() {\n\t\tString jsonStr = null;\n\t\t\n\t\tClient client = ClientBuilder.newClient();\t\t\n\t\tWebTarget target = client.target(OpenWeatherApiUtil.BASE_URL)\n\t\t\t\t.path(OpenWeatherApiUtil.WEATHER_RESOURCE)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.CITY_QUERY_PARAM, CITY_VANCOUVER)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.UNITS_QUERY_PARAM, OpenWeatherApiUtil.METRIC_UNITS)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.API_KEY_QUERY_PARAM, getApiKey());\n\n\t\tLOG.debug(\"Target URL: \" + target.getUri().toString());\n\t\t\n\t\tInvocation.Builder invocationBuilder = target.request(MediaType.APPLICATION_JSON);\t\t\n\t\t\n\t\tResponse response = invocationBuilder.get(Response.class);\t\t\n\t\tjsonStr = response.readEntity(String.class);\n\t\t\n\t\t// Check response from Open Weather API and log the response appropriately\n\t\tif (response.getStatus() == 200) {\n\t\t\tLOG.debug(jsonStr);\n\t\t}\n\t\telse {\n\t\t\tLOG.error(ErrorMessageUtils.ERROR_OPEN_WEATHER_API_RESPONSE_NON_200_STATUS\n\t\t\t\t\t+ \"\\n\" + response.readEntity(String.class));\n\t\t}\n\t\t\t\n\t\treturn jsonStr;\n\t}", "public List<String> getCity(String state) {\n\t\tSet set=new HashSet();\n\t\tList ls=new LinkedList();\n\t\tStatement statement=null;\n\t\tResultSet rs=null;\n\t\tString engineName=\"\";\n\t\ttry {\n\t\t\tstatement = connection.createStatement();\n\t\t\trs = statement.executeQuery(\"select VALUE from config_master where NAME='EXE_CITY' and LINK1='\"+state+\"'\");\n\t\t\t\n\t\t\twhile (rs.next()) {\n\t\t\t\t\t\t\t\t\n\t\t\t\tls.add(rs.getString(\"VALUE\"));\n\t\t\t}\n\n\t\t\t\n\t\t} catch (SQLException e) {\n\t\t\te.printStackTrace();\n\t\t}\n\n\t\treturn ls;\n\t}", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "public String getCity() {\n return this.city;\n }", "public String getWeather() {\n int weatherCode = 0;\n String weather = \" \";\n if (readings.size() > 0) {\n weatherCode = readings.get(readings.size() - 1).code;\n\n if (weatherCode == 100) {\n weather += weather + \" Clear \";\n } else if (weatherCode == 200) {\n weather += weather + \" Partial clouds \";\n } else if (weatherCode == 300) {\n weather += weather + \" Cloudy \";\n } else if (weatherCode == 400) {\n weather += weather + \" Light Showers \";\n } else if (weatherCode == 500) {\n weather += weather + \" Heavy Showers \";\n } else if (weatherCode == 600) {\n weather += weather + \" Rain \";\n } else if (weatherCode == 700) {\n weather += weather + \" Snow \";\n } else if (weatherCode == 800) {\n weather += weather + \" Thunder \";\n } else {\n weather += weather + \" Partial clouds \";\n }\n }\n return weather;\n }", "@Override\n public void downloadWeatherData(String zipCode){\n\n //make request to get the data\n final OkHttpClient okHttpClient;\n final Request request;\n HttpUrl url = new HttpUrl.Builder()\n .scheme(\"https\")\n .host(WEATHER_URL)\n .addPathSegment(\"api\")\n .addPathSegment(KEY)\n .addPathSegment(\"conditions\")\n .addPathSegment(\"q\")\n .addPathSegment(zipCode + \".json\")\n .build();\n\n okHttpClient = new OkHttpClient();\n request = new Request.Builder()\n .url(url)\n .build();\n\n okHttpClient.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(@NonNull Call call, @NonNull IOException e) {\n Toast.makeText(context, \"Failed to make connection\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(@NonNull Call call, @NonNull Response response) throws IOException {\n Gson gson = new Gson();\n weatherInfo = gson.fromJson(response.body().string(), WeatherInfo.class);\n view.weatherDownloadedUpdateUI(weatherInfo);\n }\n });\n\n }", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "public String getCity() {\r\n return city;\r\n }", "@GET(\"group\")\r\n\tCall<CitiesWeather> getWeather(@Query(\"id\") String ids);", "public synchronized void findCity(String cityName){\r\n\t\tLog.v(TAG, \"findCity: \"+ cityName);\r\n\t\tString url = \"http://api.wunderground.com/auto/wui/geo/GeoLookupXML/index.xml?query=\".concat(cityName);\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"City_Search\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = FIND_CITY;\r\n\t\tmsg.obj = url;\r\n\t\thandler.sendMessage(msg);\r\n\t}", "public String getCity()\n {\n \treturn city;\n }", "public interface WeatherService {\n\n @GET(\"weather?q=Givatayim,il&appid=15cf9b712a8454b5fcd0670649018163&units=metric\")\n Call<WeatherResponse> getWeather();\n\n /**\n * http://square.github.io/retrofit/2.x/retrofit/retrofit2/http/Query.html\n *\n * The @Query(\"q\") annotation appends \"&q=..the_city..\" to the end of the GET command\n *\n * @param city\n * @return\n */\n @GET(\"weather\")\n Call<WeatherResponse> getWeather(\n @Query(\"q\") String city,\n @Query(\"appid\") String key,\n @Query(\"units\") String units\n );\n\n}", "String[] getRawWeatherDataByZipcode(String zipcode) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + zipcode + \",us\" + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "public String getCity() {\n return city;\n }", "private CurrentWeather getCurrentDetails(String jsonData) throws JSONException{\n JSONObject jsonObject=new JSONObject(jsonData);\n JSONObject current=jsonObject.getJSONObject(\"currently\");\n CurrentWeather currentWeather=new CurrentWeather();\n currentWeather.setIcon(current.getString(\"icon\"));\n currentWeather.setHumidity(current.getDouble(\"humidity\"));\n currentWeather.setPreipChance(current.getInt(\"precipProbability\"));\n currentWeather.setSummary(current.getString(\"summary\"));\n currentWeather.setTime(current.getLong(\"time\"));\n currentWeather.setTemperature(current.getDouble(\"temperature\"));\n currentWeather.setTimeZone(jsonObject.getString(\"timezone\"));\n String place=jsonObject.getString(\"timezone\");\n currentWeather.setPresure(current.getDouble(\"pressure\"));\n System.out.println(place);\n return currentWeather;\n }", "public String getCity() {\n return (String) get(\"city\");\n }", "public String getCity() {\n return city;\n }", "public String getLocationCity() {\n return locationCity;\n }", "public HashMap<String,Weather> getPrecipData() {\n HashMap<String, Weather> result = new HashMap<String, Weather>();\n //String url = NOAA.PRECIP_URL.replace(\"*STARTDATE*\", startDate).replace(\"*ENDDATE*\", endDate);\n try {\n // Get and parse the JSON\n Response res = makeRequest(NOAA.PRECIP_URL);\n JsonParser parser = new JsonParser();\n JsonArray results = parser.parse(res.body().string())\n .getAsJsonObject()\n .getAsJsonArray(\"results\");\n\n // Iterate over results, storing the values un the hashmap,\n // the key is the StationID, the value is a weather object of the\n // conditions and information about the station.\n Iterator<JsonElement> iterator = results.iterator();\n while (iterator.hasNext()) {\n JsonObject e = iterator.next().getAsJsonObject();\n String type = e.get(\"datatype\").getAsString();\n String station = e.get(\"station\").getAsString();\n String attributes = e.get(\"attributes\").getAsString();\n String date = e.get(\"date\").getAsString();\n int value = e.get(\"value\").getAsInt();\n\n result.put(station, new Weather(type, station, attributes, date, value));\n }\n return result;\n } catch (IOException e) {\n e.printStackTrace();\n } catch (IllegalStateException e) {\n e.printStackTrace();\n }\n return null;\n }", "public static City buildMapFromNewYork(){\n City bangorME = new City(\"Bangor, ME\");\n \n City portlandME = new City(\"Portland, ME\");\n connect(portlandME, bangorME, 118);\n \n City portsmouthNH = new City(\"Portsmouth, NH\");\n connect(portsmouthNH, portlandME, 55);\n \n City burlingtonVT = new City(\"Burlington, VT\");\n connect(burlingtonVT, portsmouthNH, 190);\n connect(burlingtonVT, portlandME, 259);\n \n City bostonMA = new City(\"Boston, MA\");\n connect(bostonMA, portsmouthNH, 60);\n \n City providenceRI = new City(\"Providence, RI\");\n connect(providenceRI, bostonMA, 53);\n \n City worcesterMA = new City(\"Worcester, MA\");\n connect(worcesterMA, bostonMA, 49);\n connect(worcesterMA, portsmouthNH, 83);\n connect(worcesterMA, providenceRI, 44);\n \n City albanyNY = new City(\"Albany, NY\");\n connect(albanyNY, burlingtonVT, 177);\n connect(albanyNY, worcesterMA, 128);\n \n City newHavenCT = new City(\"New Haven, CT\");\n connect(newHavenCT, worcesterMA, 97);\n connect(newHavenCT, providenceRI, 100);\n \n City newYorkNY = new City(\"New York, NY\");\n connect(newYorkNY, newHavenCT, 79);\n connect(newYorkNY, albanyNY, 141);\n \n City buffaloNY = new City(\"Buffalo, NY\");\n connect(buffaloNY, albanyNY, 266);\n \n City philadelphiaPA = new City(\"Philadelphia, PA\");\n connect(philadelphiaPA, newYorkNY, 98);\n \n City washingtonDC = new City(\"Washington, DC\");\n connect(washingtonDC, philadelphiaPA, 145);\n \n City pittsburghPA = new City(\"Pittsburgh, PA\");\n connect(pittsburghPA, washingtonDC, 240);\n connect(pittsburghPA, philadelphiaPA, 288);\n connect(pittsburghPA, buffaloNY, 200);\n \n City clevelandOH = new City(\"Cleveland, OH\");\n connect(clevelandOH, pittsburghPA, 133);\n connect(clevelandOH, buffaloNY, 183);\n \n City richmondVA = new City(\"Richmond, VA\");\n connect(richmondVA, washingtonDC, 105);\n \n City charlestonWV = new City(\"Charleston, WV\");\n connect(charlestonWV, pittsburghPA, 213);\n connect(charlestonWV, washingtonDC, 343);\n connect(charlestonWV, richmondVA, 297);\n \n City charlotteNC = new City(\"Charlotte, NC\");\n connect(charlotteNC, richmondVA, 260);\n connect(charlotteNC, charlestonWV, 254);\n \n City atlantaGA = new City(\"Atlanta, GA\");\n connect(atlantaGA, charlotteNC, 229);\n \n City jacksonvilleFL = new City(\"Jacksonville, FL\");\n connect(jacksonvilleFL, atlantaGA, 300);\n connect(jacksonvilleFL, charlotteNC, 337);\n \n City miamiFL = new City(\"Miami, FL\");\n connect(miamiFL, jacksonvilleFL, 308);\n \n City tampaFL = new City(\"Tampa, FL\");\n connect(tampaFL, miamiFL, 251);\n connect(tampaFL, jacksonvilleFL, 187);\n \n City newOrleansLA = new City(\"New Orleans, LA\");\n connect(newOrleansLA, jacksonvilleFL, 473);\n connect(newOrleansLA, tampaFL, 563);\n connect(newOrleansLA, atlantaGA, 410);\n \n City nashvilleTN = new City(\"Nashville, TN\");\n connect(nashvilleTN, charlotteNC, 390);\n connect(nashvilleTN, atlantaGA, 226);\n connect(nashvilleTN, charlestonWV, 350);\n \n City memphisTN = new City(\"Memphis, TN\");\n connect(memphisTN, nashvilleTN, 191);\n connect(memphisTN, newOrleansLA, 347);\n connect(memphisTN, atlantaGA, 346);\n \n City detroitMI = new City(\"Detroit, MI\");\n connect(detroitMI, clevelandOH, 164);\n \n City indianapolisIN = new City(\"Indianapolis, IN\");\n connect(indianapolisIN, nashvilleTN, 264);\n connect(indianapolisIN, pittsburghPA, 339);\n connect(indianapolisIN, clevelandOH, 294);\n connect(indianapolisIN, detroitMI, 265);\n connect(indianapolisIN, charlestonWV, 299);\n \n City chicagoIL = new City(\"Chicago, IL\");\n connect(chicagoIL, detroitMI, 265);\n connect(chicagoIL, indianapolisIN, 177);\n \n City milwaukeeWI = new City(\"Milwaukee, WI\");\n connect(milwaukeeWI, chicagoIL, 89);\n \n City minneapolisMN = new City(\"Minneapolis, MN\");\n connect(minneapolisMN, milwaukeeWI, 300);\n \n City fargoND = new City(\"Fargo, ND\");\n connect(fargoND, minneapolisMN, 213);\n \n City siouxFallsSD = new City(\"Sioux Falls, SD\");\n connect(siouxFallsSD, fargoND, 214);\n connect(siouxFallsSD, minneapolisMN, 230);\n connect(siouxFallsSD, milwaukeeWI, 443);\n \n City omahaNE = new City(\"Omaha, NE\");\n connect(omahaNE, siouxFallsSD, 164);\n \n City desMoinesIA = new City(\"Des Moines, IA\");\n connect(desMoinesIA, omahaNE, 124);\n connect(desMoinesIA, chicagoIL, 306);\n connect(desMoinesIA, minneapolisMN, 221);\n \n City stLouisMO = new City(\"St. Louis, MO\");\n connect(stLouisMO, chicagoIL, 286);\n connect(stLouisMO, indianapolisIN, 235);\n connect(stLouisMO, nashvilleTN, 281);\n connect(stLouisMO, memphisTN, 256);\n \n City kansasCityMO = new City(\"Kansas City, MO\");\n connect(kansasCityMO, omahaNE, 168);\n connect(kansasCityMO, desMoinesIA, 176);\n connect(kansasCityMO, stLouisMO, 226);\n \n City oklahomaCityOK = new City(\"Oklahoma City, OK\");\n connect(oklahomaCityOK, kansasCityMO, 312);\n connect(oklahomaCityOK, stLouisMO, 449);\n connect(oklahomaCityOK, memphisTN, 416);\n \n City dallasTX = new City(\"Dallas, TX\");\n connect(dallasTX, oklahomaCityOK, 189);\n connect(dallasTX, memphisTN, 408);\n connect(dallasTX, newOrleansLA, 455);\n \n City houstonTX = new City(\"Houston, TX\");\n connect(houstonTX, dallasTX, 214);\n connect(houstonTX, newOrleansLA, 313);\n \n City sanAntonioTX = new City(\"San Antonio, TX\");\n connect(sanAntonioTX, dallasTX, 246);\n connect(sanAntonioTX, houstonTX, 182);\n \n City elPasoTX = new City(\"El Paso, TX\");\n connect(elPasoTX, dallasTX, 552);\n connect(elPasoTX, sanAntonioTX, 473);\n \n City albuquerqueNM = new City(\"Albuquerque, NM\");\n connect(albuquerqueNM, elPasoTX, 234);\n connect(albuquerqueNM, oklahomaCityOK, 482);\n \n City denverCO = new City(\"Denver, CO\");\n connect(denverCO, albuquerqueNM, 392);\n connect(denverCO, kansasCityMO, 528);\n connect(denverCO, omahaNE, 466);\n \n City billingsMT = new City(\"Billings, MT\");\n connect(billingsMT, denverCO, 485);\n connect(billingsMT, siouxFallsSD, 597);\n connect(billingsMT, fargoND, 529);\n \n City butteMT = new City(\"Butte, MT\");\n connect(butteMT, billingsMT, 211);\n \n City saltLakeCityUT = new City(\"Salt Lake City, UT\");\n connect(saltLakeCityUT, butteMT, 366);\n connect(saltLakeCityUT, denverCO, 480);\n \n City phoenixAZ = new City(\"Phoenix, AZ\");\n connect(phoenixAZ, elPasoTX, 379);\n connect(phoenixAZ, albuquerqueNM, 397);\n \n City lasVegasNV = new City(\"Las Vegas, NV\");\n connect(lasVegasNV, saltLakeCityUT, 369);\n connect(lasVegasNV, albuquerqueNM, 514);\n connect(lasVegasNV, phoenixAZ, 294);\n \n City losAngelesCA = new City(\"Los Angeles, CA\");\n connect(losAngelesCA, lasVegasNV, 263);\n connect(losAngelesCA, phoenixAZ, 350);\n \n City sanDiegoCA = new City(\"San Diego, CA\");\n connect(sanDiegoCA, losAngelesCA, 116);\n connect(sanDiegoCA, phoenixAZ, 335);\n connect(sanDiegoCA, lasVegasNV, 311);\n \n City montereyCA = new City(\"Monterey, CA\");\n connect(montereyCA, losAngelesCA, 319);\n \n City sanFranciscoCA = new City(\"San Francisco, CA\");\n connect(sanFranciscoCA, montereyCA, 114);\n connect(sanFranciscoCA, losAngelesCA, 358);\n \n City sacramentoCA = new City(\"Sacramento, CA\");\n connect(sacramentoCA, sanFranciscoCA, 84);\n connect(sacramentoCA, saltLakeCityUT, 585);\n \n City boiseID = new City(\"Boise, ID\");\n connect(boiseID, butteMT, 393);\n connect(boiseID, saltLakeCityUT, 301);\n \n City portlandOR = new City(\"Portland, OR\");\n connect(portlandOR, sacramentoCA, 538);\n connect(portlandOR, boiseID, 407);\n \n City seattleWA = new City(\"Seattle, WA\");\n connect(seattleWA, portlandOR, 175);\n connect(seattleWA, butteMT, 544);\n connect(seattleWA, boiseID, 472);\n \n //change this return city to start wherever you want\n return newYorkNY;\n }" ]
[ "0.7713018", "0.75237244", "0.72567314", "0.7096449", "0.7078687", "0.70262516", "0.6879343", "0.6860308", "0.6851109", "0.6815299", "0.6726035", "0.6693023", "0.668366", "0.6668463", "0.6662849", "0.66471183", "0.663934", "0.66229784", "0.6590872", "0.6558075", "0.6521022", "0.6508254", "0.6487298", "0.6479134", "0.64779687", "0.6474588", "0.64731765", "0.6448411", "0.6443436", "0.64332294", "0.6400254", "0.6399902", "0.63888705", "0.6387281", "0.63862777", "0.6372831", "0.63152033", "0.6269419", "0.6261198", "0.625765", "0.6251805", "0.62261575", "0.62207425", "0.6213315", "0.61988634", "0.61915416", "0.6187165", "0.6182928", "0.6147012", "0.6146801", "0.6140374", "0.6111383", "0.6088327", "0.60830367", "0.60756314", "0.60587513", "0.6057793", "0.60360736", "0.6028985", "0.60242844", "0.5994214", "0.59866405", "0.5934876", "0.5932591", "0.59263885", "0.592019", "0.5902703", "0.5893098", "0.5873033", "0.5867557", "0.58621156", "0.58569914", "0.5851475", "0.5850324", "0.58363265", "0.58337367", "0.58284616", "0.58280814", "0.5821011", "0.58188385", "0.5817951", "0.5817951", "0.5817951", "0.5814845", "0.57996875", "0.57973045", "0.57973045", "0.57973045", "0.5775187", "0.57743704", "0.577351", "0.57720155", "0.5764096", "0.57592964", "0.5757625", "0.57562375", "0.57370764", "0.57294834", "0.5726242", "0.5725789" ]
0.69674534
6
Get Current weather data by city name, State Code, country code
@Test(priority = 5) public void verify_Weather_Data_Appears_OnSearching_By_City_StateCodeAndCountryCode() { WeatherAPI.getWeatherInfo(ReadWrite.getProperty("Noida_City_State_Country"), ConfigFileReader.getProperty("appid"), 200); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void getWeather(String city, String units);", "@Override\n\tpublic String getWeatherDataCity(String city, String country) throws IOException {\n\n\t\treturn connectAPICity(city, country);\n\t\t\n\t}", "void handleWeatherDataForCity(String cityName);", "@GET(\"https://api.openweathermap.org/data/2.5/weather?\")\n Call<WeatherResponse> getWeatherData(@Query(\"q\") String city, @Query(\"appid\") String apiID, @Query(\"units\") String units);", "@Override\n\tpublic String getHourlyWeatherData(String city, String country) throws IOException {\n\t\t\n\t\treturn connectFiveDayForecast(city, country);\n\t\t\n\t}", "GeneralWeatherReport queryWeatherReport(String cityId);", "void loadData() {\n Request request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=20.5937,78.9629\")\n .get().build();\n //Create OkHttpClient Object\n OkHttpClient client = new OkHttpClient();\n\n // Call the request using client we just created\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n //Use this code to Handle Failed Request mostly due to internet issue\n // we will just Create a Tost Message for user\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n //Here we will check is reponse is Sucessfull or is their any\n // request error i.e url error\n if (!response.isSuccessful()) {\n //Here our reponse is UnSucessfull so we inform the user\n // about the same as before\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n //If Response is sucessfull we move forward and convert the\n // reponse which is in JSON format to String\n String respFromApi = response.body().string();\n\n //We will Log this LogCat in order to view the Raw Format recieved\n //you can open the log cat go in debug section and type RawData you\n // will be able to observe data there\n Log.d(\"RawData\", respFromApi);\n\n //Now We will call Extract Data Function which will retrieve the\n // woied and name of each city from the response\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n //Informing Data is Not in JSON Format\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n ;\n }\n });\n\n\n //---------------------------------FOR United States----------------------------------------\n\n //Following codes has similar output as before but the difference is the city Names here\n //is of United States\n request = new Request.Builder()\n .url(\"https://www.metaweather.com/api/location/search/?lattlong=38.899101,-77.028999\")\n .get().build();\n client = new OkHttpClient();\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Request request, IOException e) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(Response response) throws IOException {\n if (!response.isSuccessful()) {\n Toast.makeText(MainActivity.this, \"Request Failed\", Toast.LENGTH_SHORT).show();\n return;\n }\n String respFromApi = response.body().string();\n Log.d(\"RawData\", respFromApi);\n try {\n extractData(respFromApi);\n } catch (Exception e) {\n Toast.makeText(MainActivity.this, \"Response Not in JSON Format\", Toast.LENGTH_SHORT).show();\n }\n }\n });\n\n\n\n }", "@Cacheable(\"weather\")\r\n\tpublic Weather getWeatherByCityAndCountry(String country, String city) {\n\t\tlogger.info(\"Requesting current weather for {}/{}\", country, city);\r\n\t\t\r\n\t\tURI url = new UriTemplate(WEATHER_URL).expand(city, country, this.apiKey);\r\n\t\treturn invoke(url, Weather.class);\r\n\t}", "private void getWeatherData() {\n System.out.println(\"at getWeather\");\n String url = \"https://api.openweathermap.org/data/2.5/onecall/timemachine?lat=\";\n url += databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LATITUDE);\n url += \"&lon=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.SENDER_LONGITUDE);\n url += \"&dt=\" + databaseHandler.getSingleExperimentInfoValue(experimentNumber, DatabaseHandler.START_TIME).substring(0, 10);\n url += \"&appid=your openweathermap API key\";\n new ClientThread(ClientThread.GET_WEATHER, new String[]{url, Integer.toString(experimentNumber)}, this).start();\n }", "private void searchCity() {\n toggleProgress();\n try {\n WeatherClient client = builder.attach(this)\n .provider(new OpenweathermapProviderType())\n .httpClient(WeatherClientDefault.class)\n .config(config)\n .build();\n\n // Try to find a good location\n // using medium settings\n Criteria criteria = new Criteria();\n criteria.setPowerRequirement(Criteria.POWER_MEDIUM);\n criteria.setAccuracy(Criteria.ACCURACY_MEDIUM);\n // Can we use data?\n criteria.setCostAllowed(true);\n\n // Search city by gps/network using\n // above critera\n client.searchCityByLocation(\n criteria,\n new WeatherClient.CityEventListener() {\n\n // When we get the city list\n @Override\n public void onCityListRetrieved(List<City> cityList) {\n for (int i = 0; i < cityList.size(); i++) {\n adapter.set(cityList.get(i), i);\n }\n displayMessage(\"Not the correct results?\" +\n \" Press the button above to try again.\");\n }\n\n\n @Override\n public void onWeatherError(WeatherLibException wle) {\n displayMessage(\"There seems to be no \" +\n \"weather data, please try again later.\");\n\n }\n\n\n @Override\n public void onConnectionError(Throwable t) {\n displayMessage(\"Whoops! We can't seem to \" +\n \"connect to the weather servers.\");\n }\n\n });\n\n } catch (WeatherProviderInstantiationException e) {\n displayMessage(\"Error: Unable to access \" +\n \"the weather provider.\");\n } catch (LocationProviderNotFoundException e) {\n displayMessage(\"Whoops! Unable to access \" +\n \"location provider.\");\n } catch (NullPointerException e) {\n displayMessage(\"Whoops! We can't seem to\" +\n \"connect to the weather servers.\");\n }\n\n }", "@GET(\"/v3/weather/now.json\")\n Call<City> getCity(@Query(\"key\")String key,@Query(\"location\")String location);", "@Override\n @Cacheable(\"darkSkyFullWeather\")\n public WeatherDataDto getFullWeather(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n weatherDataDto.setPressure(pressure);\n weatherDataDto.setWindSpeed(windSpeed);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Test(priority = 2)\n\tpublic void WeatherReportForParticularCity() {\n\t\ttest.homepage.searchForLocation(ReadWrite.getProperty(\"Noida_City_State\"));\n\t\ttest.currentWeatherReportPage.verifyCurrentDayAndTime();\n\t\tweatherMap = test.currentWeatherReportPage.storeInformationOfWeather();\n\n\t}", "public void getCityData(String cityName){\n\t\tICityDataService cityDataService = new CityDataService();\n\t\tcityData = cityDataService.getCityData(cityName);\n\t}", "@Override\n protected WeatherInfo doInBackground(Void... params) {\n String weatherID = \"\";\n String areaID = \"\";\n try {\n String cityIds = null;\n if (mRequest.getRequestInfo().getRequestType()\n == RequestInfo.TYPE_WEATHER_BY_WEATHER_LOCATION_REQ) {\n cityIds = mRequest.getRequestInfo().getWeatherLocation().getCityId();\n weatherID = cityIds.split(\",\")[0];\n areaID = cityIds.split(\",\")[1];\n } else if (mRequest.getRequestInfo().getRequestType() ==\n RequestInfo.TYPE_WEATHER_BY_GEO_LOCATION_REQ) {\n double lat = mRequest.getRequestInfo().getLocation().getLatitude();\n double lng = mRequest.getRequestInfo().getLocation().getLongitude();\n\n String cityNameResponse = HttpRetriever.retrieve(String.format(GEO_URL, lat, lng));\n if (TextUtils.isEmpty(cityNameResponse)) {\n return null;\n }\n cityNameResponse = cityNameResponse.replace(\"renderReverse&&renderReverse(\", \"\").replace(\")\", \"\");\n Log.d(TAG, \"cityNameResponse\" + cityNameResponse);\n JSONObject jsonObjectCity = JSON.parseObject(cityNameResponse);\n String areaName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"district\");\n String cityName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"city\");\n areaName = TextUtil.getFormatArea(areaName);\n cityName = TextUtil.getFormatArea(cityName);\n City city = cityDao.getCityByCityAndArea(cityName, areaName);\n if (city == null) {\n city = cityDao.getCityByCityAndArea(cityName, cityName);\n if (city == null)\n return null;\n }\n weatherID = city.getWeatherId();\n areaID = city.getAreaId();\n } else {\n return null;\n }\n\n //miui天气\n String miuiURL = String.format(URL_WEATHER_MIUI, weatherID);\n if (DEBUG) Log.d(TAG, \"miuiURL \" + miuiURL);\n String miuiResponse = HttpRetriever.retrieve(miuiURL);\n if (miuiResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"Rmiuiesponse \" + miuiResponse);\n\n //2345天气\n String ttffUrl = String.format(URL_WEATHER_2345, areaID);\n if (DEBUG) Log.d(TAG, \"ttffUrl \" + ttffUrl);\n String ttffResponse = DecodeUtil.decodeResponse(HttpRetriever.retrieve(ttffUrl));\n if (ttffResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"ttffResponse \" + ttffResponse);\n\n\n JSONObject ttffAll = JSON.parseObject(ttffResponse);\n String cityName = ttffAll.getString(\"cityName\");\n //实时\n JSONObject sk = ttffAll.getJSONObject(\"sk\");\n String humidity = sk.getString(\"humidity\");\n String sk_temp = sk.getString(\"sk_temp\");\n\n //日落日升\n JSONObject sunrise = ttffAll.getJSONObject(\"sunrise\");\n\n ArrayList<WeatherInfo.DayForecast> forecasts =\n parse2345(ttffAll.getJSONArray(\"days7\"), true);\n\n WeatherInfo.Builder weatherInfo = null;\n weatherInfo = new WeatherInfo.Builder(\n cityName, sanitizeTemperature(Double.parseDouble(sk_temp), true),\n WeatherContract.WeatherColumns.TempUnit.CELSIUS);\n //湿度\n humidity = humidity.replace(\"%\", \"\");\n weatherInfo.setHumidity(Double.parseDouble(humidity));\n\n if (miuiResponse != null) {\n //风速,风向\n JSONObject weather = JSON.parseObject(miuiResponse);\n JSONObject accu_cc = weather.getJSONObject(\"accu_cc\");\n weatherInfo.setWind(accu_cc.getDouble(\"WindSpeed\"), accu_cc.getDouble(\"WindDirectionDegrees\"),\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH);\n }\n\n weatherInfo.setTimestamp(System.currentTimeMillis());\n weatherInfo.setForecast(forecasts);\n\n if (forecasts.size() > 0) {\n weatherInfo.setTodaysLow(sanitizeTemperature(forecasts.get(0).getLow(), true));\n weatherInfo.setTodaysHigh(sanitizeTemperature(forecasts.get(0).getHigh(), true));\n weatherInfo.setWeatherCondition(IconUtil.getWeatherCodeByType(\n ttffAll.getJSONArray(\"days7\").getJSONObject(0).getString(\n DateTimeUtil.isNight(sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\"))\n ? \"nightWeaShort\" : \"dayWeaShort\"), sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\")));\n }\n\n if (lastWeatherInfo != null)\n lastWeatherInfo = null;\n\n lastWeatherInfo = weatherInfo.build();\n\n return lastWeatherInfo;\n } catch (Exception e) {\n if (DEBUG) Log.w(TAG, \"JSONException while processing weather update\", e);\n }\n return null;\n }", "@Cacheable(\"darkSkyTemperature\")\n public WeatherDataDto getTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(getServiceName());\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public void getCityResult() {\n String cityNameStr = TextUtils.isEmpty(cityName) ? \"Halifax\" : cityName;\n final String url = \"http://api.openweathermap.org/data/2.5/weather?q=\" + cityNameStr + \"&appid=\" + API_KEY + \"&units=\" + CELSIUS_UNITS;\n //build the request\n JsonObjectRequest request = new JsonObjectRequest(\n Request.Method.GET, url, null, new Response.Listener<JSONObject>() {\n\n @Override\n public void onResponse(JSONObject response) {\n\n try {\n JSONArray weather = response.getJSONArray(\"weather\");\n JSONObject main = response.getJSONObject(\"main\");\n JSONObject cloudsJSON = response.getJSONObject(\"clouds\");\n\n //Set values on layout\n setCityNameOnLayout(response);\n setWeather(weather);\n setTemperature(main);\n setMinMaxTemperature(main);\n setHumidity(main);\n setClouds(cloudsJSON);\n setWeatherIcon((weather.getJSONObject(0)).get(\"icon\").toString());\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n }\n }, new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error) {\n error.printStackTrace();\n\n Toast.makeText(getApplicationContext(), \"Please, introduce an existing city\", Toast.LENGTH_SHORT).show();\n }\n }\n );\n RequestQueueSingleton.getInstance(getApplicationContext()).addToRequestQueue(request);\n }", "@Override\n public City getStatsByCity(String name) throws UnirestException {\n City cityWeather = new City();\n JSONObject object = weatherService.getWeatherByCity(name);\n Coord coord = formatObject(\"coord\",object,Coord.class);\n Wind wind = formatObject(\"wind\",object,Wind.class);\n\n Clouds clouds = formatObject(\"clouds\",object,Clouds.class);\n MainStats mainStats = formatObject(\"main\",object,MainStats.class);\n JSONObject objectWeather = object.getJSONArray(\"weather\").getJSONObject(0);\n Weather weather = mapWeather(objectWeather);\n cityWeather.setCoord(coord);\n cityWeather.setWeather(weather);\n cityWeather.setWind(wind);\n cityWeather.setClouds(clouds);\n cityWeather.setName(object.getString(\"name\"));\n cityWeather.setTimezone(object.getInt(\"timezone\"));\n cityWeather.setCod(object.getInt(\"cod\"));\n cityWeather.setVisibility(object.getInt(\"visibility\"));\n return cityWeather;\n }", "@Override\n\t\tprotected GetWeatherRes doInBackground(Void... params) {\n\t\t\treturn JsonOA.getWeatherInfo(cityId, timeStamp);\n\t\t}", "@Test(priority = 4)\n\tpublic void verify_Weather_Data_Appears_OnSearching_By_CityAndStateCode() {\n\t\tWeatherAPI.getWeatherInfo(ReadWrite.getProperty(\"London_City_State\"), ConfigFileReader.getProperty(\"appid\"),\n\t\t\t\t200);\n\n\t}", "public abstract WeatherData getCurrentWeather(LocationCoordinate _location) throws Exception;", "@Test(priority = 3)\n\tpublic void verify_Weather_Data_Appears_OnSearching_By_City() {\n\t\tweatherResponse_city = WeatherAPI.getWeatherInfo(ReadWrite.getProperty(\"Noida_City\"),\n\t\t\t\tConfigFileReader.getProperty(\"appid\"), 200);\n\n\t}", "public abstract WeatherData[] getHourlyWeatherForecast(LocationCoordinate _location) throws Exception;", "@Override\n @Cacheable(\"darkSkyWindSpeed\")\n public WeatherDataDto getWindSpeed(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String windSpeed = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"windSpeed\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setWindSpeed(windSpeed);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@GET(\"weather?APPID=bec2ea2f434c848c09196f2de96e3c4c&units=metric\")\n Single<Weather> getWeatherData(@Query(\"q\") String name);", "@Override\n @Cacheable(\"darkSkyHumidity\")\n public WeatherDataDto getHumidity(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String humidity = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"humidity\")*100);\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setHumidity(humidity);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public abstract WeatherData[] getDailyWeatherForecast(LocationCoordinate _location) throws Exception;", "@Override\n @Cacheable(\"darkSkySunriseTime\")\n public WeatherDataDto getSunriseTime(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n String sunrise = \"Api does not support this field.\";\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setSunrise(sunrise);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public WeatherForecast getForecast(String city) throws WeatherForecastClientException {\n HttpResponse<String> response;\n try {\n URI uri = new URI(\"http\", \"api.openweathermap.org\", \"/data/2.5/weather\",\n String.format(\"q=%s&units=metric&lang=bg&appid=%s\", city, apiKey), null);\n\n System.out.println(uri);\n HttpRequest request = HttpRequest.newBuilder().uri(uri).build();\n response = weatherHttpClient.send(request, HttpResponse.BodyHandlers.ofString());\n\n } catch (URISyntaxException | IOException | InterruptedException e) {\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\", e);\n }\n if (response.statusCode() == HttpURLConnection.HTTP_OK) {\n Gson gson = new Gson();\n return gson.fromJson(response.body(), WeatherForecast.class);\n } else if (response.statusCode() == HttpURLConnection.HTTP_NOT_FOUND) {\n throw new LocationNotFoundException(\"Couldn't find location with name : \" + city);\n }\n\n throw new WeatherForecastClientException(\"There was a problem with WeatherForecastClient.\");\n }", "public static Weather getNextCityWeather(){\r\n\t\t/*\r\n\t\t * While weatherDetails is getting updated with background\r\n\t\t * Handler, it shouldn't be read\r\n\t\t */\r\n\t\tsynchronized (weatherDetails) {\r\n\t\t\tString code = airportCodes.get(city_index);\r\n\t\t\tLog.i(\"WeatherRecord\", \"Display Weather of: \"+ code+ \" \"+ airportCodes.size());\r\n\t\t\tcity_index++;\r\n\t\t\tif(city_index >= airportCodes.size())\r\n\t\t\t\tcity_index = 0;\r\n\t\t\tWeather w = weatherDetails.get(code);\r\n\t\t\treturn w;\r\n\t\t}\r\n\t}", "private String connectAPICity(String city, String country) throws IOException {\n\t\t\n\t\tOkHttpClient client = new OkHttpClient();\n\t\tRequest request;\n\t\t\n\t\tif(country.isEmpty()) {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}else {\n\t\t\trequest = new Request.Builder()\n\t\t\t\t.url(\"https://community-open-weather-map.p.rapidapi.com/weather?q=\" + city + \"%2C\" + country)\n\t\t\t\t.get()\n\t\t\t\t.addHeader(\"x-rapidapi-key\", RAPID_API_KEY)\n\t\t\t\t.addHeader(\"x-rapidapi-host\", \"community-open-weather-map.p.rapidapi.com\")\n\t\t\t\t.build();\n\t\t}\n\n\t\treturn getResponse(client, request);\n\t\t\n\t}", "public WeatherData (Long sunset, Long sunrise, int weatherCode, String cityName, int temperature) {\n sunsetTime = sunset;\n sunriseTime = sunrise;\n weather = weatherCode;\n city = cityName;\n temp = temperature;\n }", "@Cacheable(\"darkSkyCityCoordinates\")\n public WeatherDataDto getCityCoordinates(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String latitude = String.valueOf(jsonObject\n .getDouble(\"latitude\"));\n String longitude = String.valueOf(jsonObject\n .getDouble(\"longitude\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setLatitude(latitude);\n weatherDataDto.setLongitude(longitude);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public void getWeatherData(View view){\n InputMethodManager imm = (InputMethodManager) getSystemService(Context.INPUT_METHOD_SERVICE);\n imm.hideSoftInputFromWindow(editText.getWindowToken(), 0);\n\n //get city name from user's input in edittext\n String cityText = editText.getText().toString();\n\n //make sure spaces between words is handled properly\n try {\n String spacedCityName= URLEncoder.encode(cityText, \"UTF-8\");\n //concatenated string for link to be opened\n String link = \"https://openweathermap.org/data/2.5/weather?q=\" + spacedCityName + \"&appid=b6907d289e10d714a6e88b30761fae22\";\n //create Download class to download data\n DownloadClass downloadClass = new DownloadClass();\n downloadClass.execute(link);\n }catch (Exception e){\n loadToast();\n e.printStackTrace();\n }\n\n\n\n }", "@GET(\"/api/\" + BuildConfig.API_KEY + \"/conditions/hourly10day/q/{zip}.json\")\n Observable<WeatherModel> fetchWeather\n (@Path(\"zip\") String zipCode);", "String[] getRawWeatherData(String city) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + city + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "public Weather getDetails(String cityName) throws SQLException, JSONException {\n Weather wSO = weatherService.getWeatherService(cityName);\n List<Cities> citySO = cityRepository.getCityDetails(cityName);\n\n return extractCityDetails(wSO, citySO);\n }", "@RequestMapping(value = \"/weather/{cityName}\", method = RequestMethod.GET)\n public ResponseEntity<Weather> getWeatherDetails(@PathVariable(\"cityName\") String cityName)\n {\n logger.info(\"Calling getWeatherDetails() method with \" + cityName + \" as param\");\n Weather weather = weatherService.getWeather(cityName);\n\n if(weather.getCurrentObservation() == null)\n {\n logger.debug(\"NULL DATA RETURNED\");\n return new ResponseEntity<Weather>(HttpStatus.NOT_FOUND);\n }\n\n return new ResponseEntity<Weather>(weather, HttpStatus.OK);\n }", "@GetMapping(\"/weather/current\")\n public Location getCurrentWeather(@RequestParam(value = \"city\", required = false) final String city, @RequestParam(value = \"country\", required = false) final String country, @RequestParam(value = \"lon\", required = false) final String lon, @RequestParam(value = \"lat\", required = false) final String lat) {\n final StringBuilder locationBuilder = new StringBuilder();\n validator.getCurrentWeatherValidator(city, country, lon, lat);\n\n if (city != null) {\n locationBuilder.append(\"city=\").append(city);\n if(country != null) {\n locationBuilder.append(\"&country=\").append(country);\n }\n } else if (lat != null) {\n final double latitude = Double.parseDouble(lat);\n final double longitude = Double.parseDouble(lon);\n final Coordinates latLong = new Coordinates(longitude, latitude);\n locationBuilder.append(latLong.getUriComponent());\n } else {\n Coordinates randomCoordinates = getRandomCoordinates();\n locationBuilder.append(randomCoordinates.getUriComponent());\n }\n\n final String location = locationBuilder.toString();\n return weatherService.getCurrentConditions(location);\n }", "net.webservicex.www.WeatherForecasts getWeatherForecasts();", "String getCity();", "@Cacheable(\"darkSkyDirectionWind\")\n public WeatherDataDto getDirectionWind(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setDirectionWind(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Override\n protected String[] doInBackground(String... params) {\n\n /* If there's no zip code, there's nothing to look up. */\n if (params.length == 0) {\n return null;\n }\n\n String location = params[0];\n URL weatherRequestUrl = NetworkUtils.buildUrl(location);\n\n try {\n String jsonWeatherResponse = NetworkUtils\n .getResponseFromHttpUrl(weatherRequestUrl);\n\n String[] simpleJsonWeatherData = OpenWeatherJsonUtils\n .getSimpleWeatherStringsFromJson(MainActivity.this, jsonWeatherResponse);\n\n return simpleJsonWeatherData;\n\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "@SneakyThrows\n String getTemperature(String city) throws MalformedURLException, IOException {\n double current_temperature = 0;\n JSONObject json = new JSONObject(IOUtils.toString(new URL(\"https://api.openweathermap.org/data/2.5/weather?q=\" + city.toLowerCase(Locale.ROOT) + \"&appid=\"), Charset.forName(\"UTF-8\")));\n current_temperature = (Float.parseFloat(json.getJSONObject(\"main\").get(\"temp\").toString()));\n current_temperature = Math.round(current_temperature*100.0)/100.0;\n System.out.println(json);\n return current_temperature + \"\";\n }", "@Cacheable(\"darkSkyFeelsLikeTemperature\")\n public WeatherDataDto getFeelsLikeTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperatureFeelsLike = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"apparentTemperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperatureFeelsLike(temperatureFeelsLike);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "private void fetchdata(String countries)\n {\n final String url = \"https://api.weatherapi.com/v1/forecast.json?key=20cc9a9b0a4243b4be970612211704&q=\"+countries+\"&days=1&aqi=no&alerts=no\";\n\n StringRequest request = new StringRequest(Request.Method.GET, url, new Response.Listener<String>() {\n @Override\n public void onResponse(String response)\n {\n\n // Handle the JSON object and\n // handle it inside try and catch\n try {\n\n // Creating object of JSONObject\n JSONObject jsonObject = new JSONObject(response);\n country.setText(\"Region: \"+jsonObject.getJSONObject(\"location\").getString(\"region\"));\n currentWeather.setText(\"Currently \"+jsonObject.getJSONObject(\"current\").getJSONObject(\"condition\").getString(\"text\"));\n humidity.setText(\"Current Humidity: \"+jsonObject.getJSONObject(\"current\").getString(\"humidity\"));\n temperature.setText(\"Current°C: \"+jsonObject.getJSONObject(\"current\").getString(\"temp_c\"));\n temperatureF.setText(\"Current°F: \"+jsonObject.getJSONObject(\"current\").getString(\"temp_f\"));\n time.setText(\"Current Time: \"+jsonObject.getJSONObject(\"location\").getString(\"localtime\"));\n countryZone.setText(\"Current Zone: \"+jsonObject.getJSONObject(\"location\").getString(\"tz_id\"));\n windD.setText(\"Direction: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_dir\"));\n windS.setText(\"Speed: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_kph\")+\" Kph\");\n windDegree.setText(\"Degree: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_degree\")+\" °\");\n\n JSONArray jsonArray = jsonObject.getJSONObject(\"forecast\").getJSONArray(\"forecastday\");\n for(int i = 0;i<jsonArray.length();i++){\n jsonObject = jsonArray.getJSONObject(i);\n tWeather = jsonObject.getJSONObject(\"day\").getJSONObject(\"condition\").getString(\"text\");\n tDate = jsonObject.getString(\"date\");\n tTempC = jsonObject.getJSONObject(\"day\").getString(\"avgtemp_c\");\n tTempF = jsonObject.getJSONObject(\"day\").getString(\"avgtemp_f\");\n tHumidity = jsonObject.getJSONObject(\"day\").getString(\"avghumidity\");\n\n phases = jsonObject.getJSONObject(\"astro\").getString(\"moon_phase\");\n sunriseT = jsonObject.getJSONObject(\"astro\").getString(\"sunrise\");\n sunsetT = jsonObject.getJSONObject(\"astro\").getString(\"sunset\");\n moonriseT = jsonObject.getJSONObject(\"astro\").getString(\"moonrise\");\n moonsetT = jsonObject.getJSONObject(\"astro\").getString(\"moonset\");\n TwillRain = jsonObject.getJSONObject(\"day\").getString(\"daily_chance_of_rain\");\n Twillsnow = jsonObject.getJSONObject(\"day\").getString(\"daily_chance_of_snow\");\n\n }\n forecastWeather.setText(tWeather+\" later\");\n tempTommorrowF.setText(\"Avg daily °F: \"+tTempF);\n tempTommorowC.setText(\"Avg daily °C: \"+tTempC);\n TchanceRain.setText(\"Chances of Rain \"+TwillRain+\" %\");\n TchanceSnow.setText(\"Chances of Snow \"+Twillsnow+\" %\");\n humidityT.setText(\"Humidity: \"+tHumidity);\n //myuri = Uri.parse(uriS);\n Tphases.setText(\"Moon Phases \"+phases);\n Tsunrise.setText(\"Sunsrise: \"+sunriseT);\n Tsunset.setText(\"Sunset: \"+sunsetT);\n Tmoonrise.setText(\"moonrise: \"+moonriseT);\n Tmoonset.setText(\"moonset: \"+moonsetT);\n\n\n }\n catch (JSONException e) {\n e.printStackTrace();\n }\n }\n },\n new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error)\n {\n Toast.makeText(\n MainActivity.this,\n error.getMessage(),\n Toast.LENGTH_SHORT)\n .show();\n }\n });\n\n RequestQueue requestQueue = Volley.newRequestQueue(this);\n requestQueue.add(request);\n requestQueue.getCache().clear();\n }", "public void callAPICall_shouldRetrieveCurrentWeatherInformation(String cityName) {\n\n WeatherAPIManager weatherAPIManager = new WeatherAPIManager(activity);\n weatherAPIManager.setOnResponseListener(new WeatherAPIManagerOnResponseListener());\n weatherAPIManager.connectToWeatherEndpoint(cityName);\n }", "void handleWeatherDataForLocation(String lon, String lat);", "@Cacheable(\"darkSkyWeatherDescription\")\n public WeatherDataDto getWeatherDescription(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setName(city);\n weatherDataDto.setWeatherDescription(constants.getMessageDoesNotSupportField());\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public synchronized void getWeeklyForecast(String city){\r\n\t\t// Create a new Handler\r\n\t\tHandlerThread handlerThread = new HandlerThread(\"Weekly_Forecast\");\r\n\t\thandlerThread.start();\r\n\t\tHandler handler = new Handler(handlerThread.getLooper(), this);\r\n\t\t\r\n\t\tMessage msg = handler.obtainMessage();\r\n\t\tmsg.what = WEEKLY_FORECAST;\r\n\t\tmsg.obj = \"http://api.wunderground.com/auto/wui/geo/ForecastXML/index.xml?query=\".concat(city);\r\n\t\thandler.sendMessage(msg);\r\n\t}", "public List<WeatherCitySummary> findAllCity(){\n return weatherCityRepository.findAllCity();\n }", "public static WeatherInfo extractWeather(String response) {\n JsonParser parser = new JsonParser();\n JsonElement jsonElement = parser.parse(response);\n JsonObject rootObject = jsonElement.getAsJsonObject();\n JsonObject location = rootObject.getAsJsonObject(\"location\");\n String city = location.get(\"name\").getAsString();\n String country = location.get(\"country\").getAsString();\n JsonObject current = rootObject.getAsJsonObject(\"current\");\n Double temp = current.get(\"temp_c\").getAsDouble();\n JsonObject condition = current.getAsJsonObject(\"condition\");\n String conditionText = condition.get(\"text\").getAsString();\n return new WeatherInfo(city, country, conditionText, temp);\n}", "@Override\n @Cacheable(\"darkSkyPressure\")\n public WeatherDataDto getPressure(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String pressure = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"pressure\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(ServiceName.DARK_SKY);\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setPressure(pressure);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "@Override\n \t\tprotected Void doInBackground(Void... params) {\n \t\t\tgetJSONFromUrl(fore_city,fore_country);\n\n \t\t\treturn null;\n \t\t}", "private void getHttpResponse() {\n String url = \"https://api.openweathermap.org/data/2.5/weather?id=\"+city.getId()+\"&units=metric&appid=77078c41435ef3379462eb28afbdf417\";\n\n Request request = new Request.Builder()\n .url(url)\n .header(\"Accept\", \"application/json\")\n .header(\"Content-Type\", \"application/json\")\n .build();\n\n client.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(Call call, IOException e) {\n String message = e.getMessage();\n System.out.println(message);\n }\n\n /**\n * Update the UI with the information\n * @param call\n * @param response\n * @throws IOException\n */\n @Override\n public void onResponse(Call call, Response response) throws IOException {\n String body = response.body().string();\n\n Gson gson = new Gson();\n CityInfoDto cityInfo = gson.fromJson(body, CityInfoDto.class);\n\n setNewValues(Math.round(cityInfo.main.temp), cityInfo.weather[0].main);\n setBackground();\n }\n });\n }", "private List<Tuple> weatherMap(Tuple input) {\n \n Map<String, String> mockLocationService = new HashMap<String, String>();\n mockLocationService.put(\"Harrisburg\", \"PA\");\n mockLocationService.put(\"Pittsburgh\", \"PA\");\n mockLocationService.put(\"Phildelphia\", \"PA\");\n mockLocationService.put(\"Houston\", \"TX\");\n mockLocationService.put(\"SanAntonio\", \"TX\");\n mockLocationService.put(\"Austin\", \"TX\");\n mockLocationService.put(\"Sacramento\", \"CA\");\n mockLocationService.put(\"LosAngeles\", \"CA\");\n mockLocationService.put(\"SanFransico\", \"CA\");\n \n List<Tuple> output = new ArrayList<Tuple>();\n \n String city = input.fst();\n String hiLow = input.snd();\n \n output.add(new Tuple(mockLocationService.get(city), hiLow));\n \n lolligag();\n \n //<state, hi low>\n return output;\n }", "public List<InputData> getCityData(String city) {\n String SQL = \"SELECT * FROM world_bank WHERE city = ?\";\n List<InputData> records = jdbcTemplate.query(SQL,\n new Object[] { city }, new DataMapper());\n return records;\n }", "@Test\n\t@Title(\"TC_008: Verify that the current weather data is returned correctly when user search for the City Name\")\n\t \n\tpublic void TC_008_Verify_CurrentWeatherInfo_Is_Returned_For_ValidCity() {\n\t\t\n\t\tLocation city = new Location();\n\t\t\n\t\tcity = DataReader.RetrieveLocationFromFile(\"data.json\").get(0);\n\t\t\n\t\tcity.weather = new Weather(\"C\");\n\t\t\n\t\t//Steps:\n\t\t//1. Access to the site\n\t\tendUser.access_Site();\n\t\t\n\t\t//Search Weather by CityName\n\t\tendUser.SearchWeatherbyCityName(city);\n\t\t\n\t\t//Assume that the test application is triggering the correct API as expectation: OncCall\n\t\tcity = endUser.getWeatherInfoViaAPIResponse(city);\n\t\t\n\t\t//Validate Current Weather\n\t\tendUser.Validate_CurrentWeather(city);\n\t\t\n\t\tAssert.assertTrue(TestConfigs.glb_TCFailedMessage, TestConfigs.glb_TCStatus);\n\t}", "private static boolean fetchYahooWeather() {\n try {\n SAXParserFactory spf = SAXParserFactory.newInstance();\n spf.setNamespaceAware(true);\n SAXParser parser = spf.newSAXParser();\n \n String yql_format = String.format(\"select %%s from %%s where woeid in (select woeid from geo.places(1) where text=\\\"%s, %s\\\")\", CITY, ST);\n \n /* Fetch Wind Data (temp, windDir, and windSpeed) */\n String yql_wind = String.format(yql_format, \"wind\", \"weather.forecast\");\n String url_wind = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_wind, \"UTF-8\"));\n \n DefaultHandler wind_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:wind\")) return;\n \n temp = Integer.parseInt(attributes.getValue(\"chill\"));\n \n int dir = Integer.parseInt(attributes.getValue(\"direction\")); // number from 0-359 indicating direction\n // I began writing an if tree, then remembered I was lazy.\n String[] dir_words = new String[] {\n \"east\", \"northeast\", \"north\", \"northwest\", \"west\", \"southwest\", \"south\", \"southeast\"\n };\n windDir = dir_words[dir/45];\n \n windSpeed = Integer.parseInt(attributes.getValue(\"speed\")); // speed in mph\n }\n };\n parser.parse(url_wind, wind_handler);\n \n /* Fetch Atronomy Data (sunriseHour and sunsetHour) */\n String yql_astro = String.format(yql_format, \"astronomy\", \"weather.forecast\");\n String url_astro = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_astro, \"UTF-8\"));\n \n DefaultHandler astro_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:astronomy\")) return;\n \n sunriseHour = Util.parseTime(attributes.getValue(\"sunrise\"));\n sunsetHour = Util.parseTime(attributes.getValue(\"sunset\"));\n \n }\n };\n parser.parse(url_astro, astro_handler);\n \n /* Fetch Description Data (sky) */\n String yql_sky = String.format(yql_format, \"item.condition.text\", \"weather.forecast\");\n String url_sky = String.format(\"https://query.yahooapis.com/v1/public/yql?q=%s&format=xml&u=f\", URLEncoder.encode(yql_sky, \"UTF-8\"));\n \n DefaultHandler sky_handler = new DefaultHandler() {\n public void startElement(String uri, String localName, String qName, Attributes attributes) throws SAXException {\n //System.out.printf(\"uri=%s\\nlocalName=%s\\nqName=%s\\nattributes=%s\\n\\n\", uri, localName, qName, attributes);\n if (!qName.equals(\"yweather:condition\")) return;\n \n sky = attributes.getValue(\"text\").toLowerCase();\n \n }\n };\n parser.parse(url_sky, sky_handler);\n \n return E.sky != null;\n \n } catch (java.net.UnknownHostException uhe) {\n if (Data.DEBUG) System.err.println(\"You are offline!\");\n return false;\n } catch (Exception e) {\n e.printStackTrace();\n return false;\n }\n }", "public static String getCityWeatherInfos(float latitude, float longitude) {\n\t\tString urlString = \"https://api.openweathermap.org/data/2.5/weather?lat=\" + latitude \n\t\t\t\t+ \"&lon=\" + longitude + \"&appid=\" + API_KEY;\n\t\t\n\t\tStringBuilder result = new StringBuilder();\n\t\t\n\t\ttry {\n\t\t\tURL url = new URL(urlString);\n\t\t\tURLConnection conn = url.openConnection();\n\t\t\t\n\t\t\tBufferedReader rd = new BufferedReader(new InputStreamReader(conn.getInputStream()));\n\t\t\tString line;\n\t\t\t\n\t\t\twhile ((line = rd.readLine()) != null) {\n\t\t\t\tresult.append(line);\n\t\t\t}\n\t\t\t\n\t\t\trd.close();\n\t\t\tSystem.out.println(result);\n\t\t} catch (Exception e) {\n\t\t\tSystem.out.println(e.getMessage());\n\t\t\t// TODO: handle exception\n\t\t}\t\n\t\t\tString weatherInfos = result.toString();\n\t\t\t\n\t\t\treturn weatherInfos;\n\t}", "java.lang.String getCityName();", "public double getWeatherAPI() {\n\t\tRestAssured.baseURI= props.getProperty(\"BaseURI\");\n\t\tString response = \tgiven().log().all().header(\"Content-Type\",\"application/json\").\n\t\t\t\tqueryParam(\"q\", props.getProperty(\"city\")).\n\t\t\t\tqueryParam(\"appid\", props.getProperty(\"key\")).\n\t\t\t\tqueryParam(\"units\", props.getProperty(\"unit\"))\n\t\t\t\t.when().get(\"data/2.5/weather\")\n\t\t\t\t.then().log().all().assertThat().statusCode(200).header(\"charset\", \"UTF-8\").extract().response().asString();\n\n\n\t\tSystem.out.println(response);\n\n\t\tJsonPath json = new JsonPath(response); // parsing the String response to Json\n\t\tString temp = json.getString(\".main.temp\");\n\t\tSystem.out.println(temp);\n\t\t\n\t\tdouble tempurature = Double.parseDouble(temp);\n\t\t\n\t\treturn tempurature;\n\t\t\n\t\t\n\t\t\n\t}", "public HashMap<String,Weather> getPrecipData() {\n HashMap<String, Weather> result = new HashMap<String, Weather>();\n //String url = NOAA.PRECIP_URL.replace(\"*STARTDATE*\", startDate).replace(\"*ENDDATE*\", endDate);\n try {\n // Get and parse the JSON\n Response res = makeRequest(NOAA.PRECIP_URL);\n JsonParser parser = new JsonParser();\n JsonArray results = parser.parse(res.body().string())\n .getAsJsonObject()\n .getAsJsonArray(\"results\");\n\n // Iterate over results, storing the values un the hashmap,\n // the key is the StationID, the value is a weather object of the\n // conditions and information about the station.\n Iterator<JsonElement> iterator = results.iterator();\n while (iterator.hasNext()) {\n JsonObject e = iterator.next().getAsJsonObject();\n String type = e.get(\"datatype\").getAsString();\n String station = e.get(\"station\").getAsString();\n String attributes = e.get(\"attributes\").getAsString();\n String date = e.get(\"date\").getAsString();\n int value = e.get(\"value\").getAsInt();\n\n result.put(station, new Weather(type, station, attributes, date, value));\n }\n return result;\n } catch (IOException e) {\n e.printStackTrace();\n } catch (IllegalStateException e) {\n e.printStackTrace();\n }\n return null;\n }", "public static String getWoeid(String city)\n {\n try {\n String inline = useAPI(\"https://www.metaweather.com/api/location/search/?query=\" + city);\n if (!inline.equals(\"[]\")) {\n String[] words = inline.split(\",\");\n String[] erg = words[2].split(\":\");\n return erg[1];\n }\n } catch (IOException e) {\n e.printStackTrace();\n }\n return null;\n }", "void fetchCountryInformation();", "public interface IWeatherProvider {\r\n\r\n public CurrentWeather getCurrentCondition(String data) throws WeatherLibException;\r\n\r\n public WeatherForecast getForecastWeather(String data) throws WeatherLibException;\r\n\r\n public List<City> getCityResultList(String data) throws WeatherLibException;\r\n\r\n public WeatherHourForecast getHourForecastWeather(String data) throws WeatherLibException;\r\n\r\n public String getQueryCityURL(String cityNamePattern) throws ApiKeyRequiredException;\r\n\r\n // public String getQueryCurrentWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n // public String getQueryForecastWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n public HistoricalWeather getHistoricalWeather(String data) throws WeatherLibException;\r\n\r\n public String getQueryCityURLByLocation(Location location) throws ApiKeyRequiredException;\r\n\r\n public String getQueryCityURLByCoord(double lon, double lat) throws ApiKeyRequiredException;\r\n\r\n\r\n public void setConfig(WeatherConfig config);\r\n\r\n public void setWeatherCodeProvider(IWeatherCodeProvider codeProvider);\r\n\r\n public String getQueryImageURL(String weatherId) throws ApiKeyRequiredException;\r\n\r\n //public String getQueryHourForecastWeatherURL(String cityId) throws ApiKeyRequiredException;\r\n\r\n //public String getQueryHistoricalWeatherURL(String cityId, Date startDate, Date endDate) throws ApiKeyRequiredException;\r\n\r\n public String getQueryLayerURL(String cityId, Params params) throws ApiKeyRequiredException;\r\n\r\n\r\n\r\n public String getQueryCurrentWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryForecastWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryHourForecastWeatherURL(WeatherRequest request) throws ApiKeyRequiredException;\r\n\r\n public String getQueryHistoricalWeatherURL(WeatherRequest request, Date startDate, Date endDate) throws ApiKeyRequiredException;\r\n\r\n}", "Weather getById(Long id);", "public ArrayList<Weather> getDarkSkyWeather(String longitude, String latitude) {\n\n Log.i(\"long: \", longitude);\n Log.i(\"lat: \", latitude);\n\n Weather weather = new Weather();\n ArrayList<Weather> weatherArr = new ArrayList<Weather>();\n ArrayList<String> temp = new ArrayList<String>();\n String content;\n try {\n content = weather.execute(\"https://api.darksky.net/forecast/a4b289aa3abfbee48b4fc1df98208a34/\"+ latitude + \",\" + longitude + \"?lang=vi&exclude=minutely,flags,currently\").get();\n\n if(content == null)\n {\n return null;\n }\n JSONObject obj = new JSONObject(content);\n\n JSONObject daily = obj.getJSONObject(\"daily\");\n JSONArray dataDaily = daily.getJSONArray(\"data\");\n\n String summary;\n String temperatureMin;\n String temperatureMax;\n String humidity;\n String windSpeed;\n String windGust;\n String airPressure;\n String visibility;\n String ozoneDensity;\n String uvIndex;\n String cloudCover;\n String precipProbability;\n String time;\n\n Bundle bundle2 = new Bundle();\n images = new Integer[dataDaily.length()];\n\n for(int i = 0; i < dataDaily.length(); i++)\n {\n Weather result = new Weather();\n\n JSONObject detail = dataDaily.getJSONObject(i);\n\n summary = detail.getString(\"summary\");\n temperatureMin = detail.getString(\"temperatureMin\");\n temperatureMax = detail.getString(\"temperatureMax\");\n precipProbability = detail.getString(\"precipProbability\");\n humidity = detail.getString(\"humidity\");\n windSpeed = detail.getString(\"windSpeed\");\n windGust = detail.getString(\"windGust\");\n airPressure = detail.getString(\"pressure\");\n visibility = detail.getString(\"visibility\");\n ozoneDensity = detail.getString(\"ozone\");\n uvIndex = detail.getString(\"uvIndex\");\n cloudCover = detail.getString(\"cloudCover\");\n time = unixTimeToDate(detail.getString(\"time\"));\n\n\n String precipProb = String.valueOf(String.format(\"%.0f\", (Float.parseFloat(precipProbability)*100))+ \"%\");\n\n // Update UI\n result.setDate(normalizeDate(time.substring(0, 10)));\n result.setWeather(summary);\n result.setDescription(\"Khả năng mưa: \" + precipProb);\n result.setTemperature(celsiusToFahrenheit(temperatureMax) + \"\\u2103\");\n result.setWind(\"Gió: \" + windSpeed + \"mph\");\n weatherArr.add(result);\n\n if(summary.toLowerCase().contains(\"quang\"))\n {\n images[i] = R.drawable.sunny;\n }\n if(summary.toLowerCase().contains(\"mưa\"))\n {\n images[i] = R.drawable.rainy;\n }\n else if (summary.toLowerCase().contains(\"âm u\"))\n {\n images[i] = R.drawable.foggy;\n }\n else if (summary.toLowerCase().contains(\"mây\"))\n {\n images[i] = R.drawable.cloudy;\n }\n else\n {\n images[i] = R.drawable.sunny;\n }\n\n\n// Bundle bundlee = new Bundle();\n// ArrayList<String> dailyData = new ArrayList<String>();\n//\n// dailyData.add(summary);\n// dailyData.add(precipProb);\n// dailyData.add(normalizeDate(time.substring(0, 10)));\n// dailyData.add(temperatureMin +\"\\u2103\");\n// dailyData.add(temperatureMax +\"\\u2103\");\n// dailyData.add(humidity + \"%\");\n// dailyData.add(windSpeed + \" mph\");\n// dailyData.add(windGust + \" mph\");\n// dailyData.add(airPressure + \" mb\");\n// dailyData.add(visibility + \" mi\");\n// dailyData.add(ozoneDensity + \" DU\");\n// dailyData.add(uvIndex);\n// dailyData.add(cloudCover);\n// dailyData.add(String.valueOf(i)); // fragment-tag\n//\n// bundlee.putStringArrayList(\"daily-data\",dailyData);\n\n\n Bundle bundle = new Bundle();\n bundle.putString(\"weather\", summary);\n bundle.putString(\"PoP\", precipProb);\n bundle.putString(\"date\", normalizeDate(time.substring(0, 10)));\n bundle.putString(\"tempMin\", temperatureMin +\"\\u2103\");\n bundle.putString(\"tempMax\", temperatureMax +\"\\u2103\");\n bundle.putString(\"humidity\", humidity + \"%\");\n bundle.putString(\"windSpeed\", windSpeed + \" mph\");\n bundle.putString(\"winGust\", windGust + \" mph\");\n bundle.putString(\"airPressure\", airPressure + \" mb\");\n bundle.putString(\"visibility\", visibility + \" mi\");\n bundle.putString(\"ozoneDensity\", ozoneDensity + \" DU\");\n bundle.putString(\"uvIndex\", uvIndex);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTag\", String.valueOf(i));\n\n temp.add(temperatureMin);\n\n bundleDailyArr.add(bundle);\n// bundleDailyArr.add(bundlee);\n\n// Log.i(\"Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n for(int i = 0; i < temp.size(); i++)\n {\n bundle2.putString(\"temp\"+String.valueOf(i), temp.get(i));\n }\n\n\n\n// Get weather hourly\n\n JSONObject hourly = obj.getJSONObject(\"hourly\");\n JSONArray dataHourly = hourly.getJSONArray(\"data\");\n String temperature;\n\n for(int i = 0; i < dataHourly.length(); i++)\n {\n JSONObject detail = dataHourly.getJSONObject(i);\n\n temperature = detail.getString(\"temperature\");\n precipProbability = detail.getString(\"precipProbability\");\n windSpeed = detail.getString(\"windSpeed\");\n cloudCover = detail.getString(\"cloudCover\");\n\n Bundle bundle = new Bundle();\n bundle.putString(\"PoP\", precipProbability);\n //bundle.putString(\"temp\", String.valueOf((int)(Float.parseFloat(temperatureMin) + Float.parseFloat(temperatureMax) / 2)));\n bundle.putString(\"temperature\", temperature);\n bundle.putString(\"windSpeed\", windSpeed);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTagasd\", String.valueOf(i));\n\n\n bundleHourlyArr.putBundle(String.valueOf(i),bundle);\n\n\n Log.i(\"Hourly Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n return weatherArr;\n }", "public interface IWeatherDataProvider {\n\n\tpublic WeatherData getWeatherData(Location location);\n\t\n}", "public YahooWeatherInformation getResult_Weather_Information(){\n return this.Result_Weather_Information;\n }", "protected String[] doInBackground(String... args) {\n //Create string xml\n String xml;\n String cityName = \"Custom Location\";\n //if statement to determine if city name or coords\n if (args.length == 1) {\n //set xml to String returned from Function.executeGet() method sending API request to http address as parameter\n xml = Function.excuteGet(\"http://api.openweathermap.org/data/2.5/weather?q=\" + args[0] +\n \"&units=metric&appid=\" + OPEN_WEATHER_MAP_API);\n\n try {\n JSONObject json = new JSONObject(xml);\n JSONObject coord = json.getJSONObject(\"coord\");\n String lat = coord.getString(\"lat\");\n String lon = coord.getString(\"lon\");\n cityName = json.getString(\"name\");\n\n xml = Function.excuteGet(\"https://api.openweathermap.org/data/2.5/onecall?lat=\" + lat + \"&lon=\" + lon + \"&exclude=minutely&units=metric&appid=\" + OPEN_WEATHER_MAP_API);\n } catch (JSONException e) {\n e.printStackTrace();\n }\n } else {\n\n xml = Function.excuteGet(\"http://api.openweathermap.org/data/2.5/weather?lat=\" + args[0] + \"&lon=\" + args[1] +\n \"&units=metric&appid=\" + OPEN_WEATHER_MAP_API);\n try {\n\n JSONObject json = new JSONObject(xml);\n cityName = json.getString(\"name\");\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n\n\n //set xml to String returned from Function.executeGet() method sending API request to http address as parameter\n xml = Function.excuteGet(\"https://api.openweathermap.org/data/2.5/onecall?lat=\" + args[0] +\n \"&lon=\" + args[1] + \"&exclude=minutely&units=metric&appid=\" + OPEN_WEATHER_MAP_API);\n }\n\n String[] json = {xml, cityName};\n\n return json;\n }", "public void downloadWeatherForCurrentLocation() {\n if(checkConnection()) {\n LocationManager locationManager = LocationManager.getInstance(this, view);\n locationManager.getCoordinates();\n } else {\n showNoConnectionDialog();\n }\n }", "private CurrentWeather getCurrentDetails(String jsonData) throws JSONException{\n JSONObject jsonObject=new JSONObject(jsonData);\n JSONObject current=jsonObject.getJSONObject(\"currently\");\n CurrentWeather currentWeather=new CurrentWeather();\n currentWeather.setIcon(current.getString(\"icon\"));\n currentWeather.setHumidity(current.getDouble(\"humidity\"));\n currentWeather.setPreipChance(current.getInt(\"precipProbability\"));\n currentWeather.setSummary(current.getString(\"summary\"));\n currentWeather.setTime(current.getLong(\"time\"));\n currentWeather.setTemperature(current.getDouble(\"temperature\"));\n currentWeather.setTimeZone(jsonObject.getString(\"timezone\"));\n String place=jsonObject.getString(\"timezone\");\n currentWeather.setPresure(current.getDouble(\"pressure\"));\n System.out.println(place);\n return currentWeather;\n }", "private static void getWeatherDataForInputValues(BigDecimal lat, BigDecimal lon) throws RemoteException{\n\t\t\n\t\tCalendar time = new GregorianCalendar();\t\t\t\t// Pass this as a GregorianCalendar for the Calendar to understand\n\t\ttime.setTime(new Date());\n\t\tSystem.out.println(\"Fetaching data from SOAP Web Service... Please wait\");\n\t\tString result = proxy.NDFDgen(lat,lon,\"time-series\",time,time,\"e\",wp);\n\t\tDocument dom= convertStringToDocument(result);\n\t\ttry{\n\t\t\t//Displaying the result on the output screen\n\t\t\tXPathFactory xpathFactory = XPathFactory.newInstance();\n\t\t\tXPath xpath = xpathFactory.newXPath();\n\t\t\tSystem.out.println(\"Minimum Temperature: \"+getValuesFromDom(dom,xpath,\"temperature[@type='minimum']\")); //print the minimum temp\n\t\t\tSystem.out.println(\"Maximum Temperature: \"+getValuesFromDom(dom,xpath,\"temperature[@type='maximum']\")); // print the maximum temp\n\t\t\tSystem.out.println(\"Wind Direction: \"+getValuesFromDom(dom,xpath,\"direction\")); // print the wind direction\n\t\t\tSystem.out.println(\"Wind Speed: \"+getValuesFromDom(dom,xpath,\"wind-speed\")); // print the wind speed\n\t\t\tSystem.out.println(\"Temperature Dew point: \"+getValuesFromDom(dom,xpath,\"temperature[@type='dew point']\")); // print the dew point temperature\n\t\t\tSystem.out.println(\"12 Hour Probability of Precipitation:\"+getValuesFromDom(dom,xpath,\"probability-of-precipitation\"));\n\t\t\tString command = isRefreshed();\n\t\t\tif(command.trim().toLowerCase().equals(\"yes\")){\n\t\t\t\t\n\t\t\t\tgetWeatherDataForInputValues(lat,lon);\n\t\t\t}\n\t\t\t\n\t\t}catch(Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}", "public CityDailyWeather(String city, int startYear, int endYear, int stationID){\n\t\tthis.city = city;\n\t\tthis.startYear = startYear;\n\t\tthis.endYear = endYear;\n\t\tthis.stationID = stationID;\n\t}", "@Override\n public rx.Observable<CityWeather> getForecast(final String cityId) {\n return Observable.create(new Observable.OnSubscribe<CityWeather>() {\n @Override\n public void call(Subscriber<? super CityWeather> subscriber) {\n try {\n subscriber.onNext(getCityWeatherFromCityId(cityId));\n } catch (Exception e) {\n subscriber.onError(e);\n } finally {\n subscriber.onCompleted();\n }\n }\n });\n }", "@Override\n public void downloadWeatherDataHourly(String zipCode){\n\n //make request to get the l\n final OkHttpClient okHttpClient;\n final Request request;\n HttpUrl url = new HttpUrl.Builder()\n .scheme(\"https\")\n .host(WEATHER_URL)\n .addPathSegment(\"api\")\n .addPathSegment(KEY)\n .addPathSegment(\"hourly10day\")\n .addPathSegment(\"q\")\n .addPathSegment(zipCode + \".json\")\n .build();\n\n okHttpClient = new OkHttpClient();\n request = new Request.Builder()\n .url(url)\n .build();\n\n okHttpClient.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(@NonNull Call call, @NonNull IOException e) {\n Toast.makeText(context, \"Failed to make connection\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(@NonNull Call call, @NonNull Response response) throws IOException {\n Gson gson = new Gson();\n hourlyWeatherInfo = gson.fromJson(response.body().string(), HourlyWeatherInfo.class);\n view.hourlyWeatherDownloadedUpdateUI(hourlyWeatherInfo);\n }\n });\n\n }", "@GET(\"group\")\r\n\tCall<CitiesWeather> getWeather(@Query(\"id\") String ids);", "public interface WeatherService {\n\n @GET(\"weather?q=Givatayim,il&appid=15cf9b712a8454b5fcd0670649018163&units=metric\")\n Call<WeatherResponse> getWeather();\n\n /**\n * http://square.github.io/retrofit/2.x/retrofit/retrofit2/http/Query.html\n *\n * The @Query(\"q\") annotation appends \"&q=..the_city..\" to the end of the GET command\n *\n * @param city\n * @return\n */\n @GET(\"weather\")\n Call<WeatherResponse> getWeather(\n @Query(\"q\") String city,\n @Query(\"appid\") String key,\n @Query(\"units\") String units\n );\n\n}", "@Override\n public void downloadWeatherData(String zipCode){\n\n //make request to get the data\n final OkHttpClient okHttpClient;\n final Request request;\n HttpUrl url = new HttpUrl.Builder()\n .scheme(\"https\")\n .host(WEATHER_URL)\n .addPathSegment(\"api\")\n .addPathSegment(KEY)\n .addPathSegment(\"conditions\")\n .addPathSegment(\"q\")\n .addPathSegment(zipCode + \".json\")\n .build();\n\n okHttpClient = new OkHttpClient();\n request = new Request.Builder()\n .url(url)\n .build();\n\n okHttpClient.newCall(request).enqueue(new Callback() {\n @Override\n public void onFailure(@NonNull Call call, @NonNull IOException e) {\n Toast.makeText(context, \"Failed to make connection\", Toast.LENGTH_SHORT).show();\n }\n\n @Override\n public void onResponse(@NonNull Call call, @NonNull Response response) throws IOException {\n Gson gson = new Gson();\n weatherInfo = gson.fromJson(response.body().string(), WeatherInfo.class);\n view.weatherDownloadedUpdateUI(weatherInfo);\n }\n });\n\n }", "@Test(dataProvider=\"WeatherTests\", dataProviderClass=DataProviders.class, enabled=true)\n\tpublic void WeatherTests(TestInput testInput) {\n\t\ttest = extent.startTest(\"Weather Test for \" + testInput.cityName);\n\t\ttest.log(LogStatus.INFO, \"Starting tests for \" + testInput.cityName);\n\n\t\ttry {\n\t\t\t//Checks if we were able to find an entry for the given city in the cities.json file\n\t\t\tif(testInput.city.id != null) {\n\t\t\t\tlog.debug(\"Found an entry for the city \" + testInput.cityName + \" in the Cities JSON File. Starting.\");\n\n\t\t\t\t//Extract the weather information from API for the given city\n\t\t\t\tCityWeatherInfo currenctCityWeatherInfoAPI = APIRequests.extractLatestWeatherForecastFromAPI(testInput, config.getProperty(\"APIKEY\"));\n\n\t\t\t\t//Extract the weather information from the website\n\t\t\t\tHomePage home = new HomePage();\n\t\t\t\thome.setTemperatureToFarenheit(); //Switch temperature to farenheit to be inline with the information from API\n\n\t\t\t\tSearchResultsPage resultsPage = home.searchCity(testInput.cityName.trim());\n\t\t\t\tCityWeatherPage cityWeatherPage = resultsPage.clickOnCityEntry(testInput.city.id.trim());\n\n\t\t\t\tArrayList<Double> forecastWeathers = cityWeatherPage.extractForecastTemperatures();\n\t\t\t\tcityWeatherPage.navigateToHourlyTab();\n\t\t\t\tCityWeatherInfo currenctCityAPIWeatherInfoWeb = cityWeatherPage.extractFirstForecastInfo();\n\n\t\t\t\t//////////// TEST 1 //////////////\n\t\t\t\t//Checks to see if the forecast weather information from API matches the data from website\n\t\t\t\tif(currenctCityWeatherInfoAPI.equals(currenctCityAPIWeatherInfoWeb))\n\t\t\t\t\ttest.log(LogStatus.PASS, \"TEST1: Weather information from API matches with website\");\n\t\t\t\telse {\n\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Weather information from API does not match with website\");\n\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.temperatureInFarenheit != currenctCityAPIWeatherInfoWeb.temperatureInFarenheit)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Temperature from API (\" + currenctCityWeatherInfoAPI.temperatureInFarenheit +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Temperature from Web (\" + currenctCityAPIWeatherInfoWeb.temperatureInFarenheit + \")\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.windSpeedInMPH != currenctCityAPIWeatherInfoWeb.windSpeedInMPH)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Wind Speed from API (\" + currenctCityWeatherInfoAPI.windSpeedInMPH +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Wind Speed from Web (\" + currenctCityAPIWeatherInfoWeb.windSpeedInMPH + \")\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.cloudCoverPercentage != currenctCityAPIWeatherInfoWeb.cloudCoverPercentage)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Cloud Coverage from API (\" + currenctCityWeatherInfoAPI.cloudCoverPercentage +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\"%) does not match Cloud Coverage from Web (\" + currenctCityAPIWeatherInfoWeb.cloudCoverPercentage + \"%)\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.atmPressureInHPA != currenctCityAPIWeatherInfoWeb.atmPressureInHPA)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Atmospheric Pressure from API (\" + currenctCityWeatherInfoAPI.atmPressureInHPA +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Atmospheric Pressure from Web (\" + currenctCityAPIWeatherInfoWeb.atmPressureInHPA + \")\");\n\t\t\t\t}\n\n\t\t\t\t//////////// TEST 2 //////////////\n\t\t\t\t//Check whether the difference between minimum and maximum forecast temperature listed on website is less than 10 or not\n\t\t\t\tdouble minForecastWeather = Common.minValueInList(forecastWeathers), maxForecastWeather = Common.maxValueInList(forecastWeathers);\n\t\t\t\tdouble diffForecastWeather = maxForecastWeather - minForecastWeather; \n\t\t\t\tif(diffForecastWeather <= 10)\n\t\t\t\t\ttest.log(LogStatus.PASS, \"TEST2: Difference between Maximum Forecast Temperature (\" + maxForecastWeather + \") \"\n\t\t\t\t\t\t\t\t\t\t\t\t+ \"and Minimum Forecast Temperature (\" + minForecastWeather + \") is \" + diffForecastWeather\n\t\t\t\t\t\t\t\t\t\t\t\t+ \" which is less than 10 degrees farenheit\");\n\t\t\t\telse\n\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST2: Difference between Maximum Forecast Temperature (\" + maxForecastWeather + \") \"\n\t\t\t\t\t\t\t\t\t\t\t\t+ \"and Minimum forecast temperature (\" + minForecastWeather + \") is \" + diffForecastWeather\n\t\t\t\t\t\t\t\t\t\t\t\t+ \" which is greater than 10 degrees farenheit\");\n\t\t\t} else {\n\t\t\t\tlog.debug(\"Could not find an entry for the city \" + testInput.cityName + \" in the Cities JSON File. Skipping.\");\n\t\t\t\ttest.log(LogStatus.FAIL, \"Unable to find entry in cities.json for the city: \" + testInput.cityName);\n\t\t\t}\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t} finally {\n\t\t\textent.endTest(test);\n\t\t}\n\t}", "public interface WeatherService {\n\n @GET(\"weather\")\n Call<ClaseCiudad> getCity(@Query(\"q\") String city, @Query(\"appid\") String key);\n\n @GET(\"weather\")\n Call<ClaseCiudad> getCity(@Query(\"id\") int idCity, @Query(\"appid\") String key);\n\n @GET(\"weather\")\n Call<ClaseCiudad> getCity(@Query(\"id\") int idCity, @Query(\"appid\") String key, @Query(\"units\") String value);\n\n @GET(\"weather\")\n Call<ClaseCiudad> getCity(@Query(\"id\") int idCity, @Query(\"appid\") String key, @Query(\"units\") String value, @Query(\"lang\") String lang);\n\n }", "public String getWeather() {\n int weatherCode = 0;\n String weather = \" \";\n if (readings.size() > 0) {\n weatherCode = readings.get(readings.size() - 1).code;\n\n if (weatherCode == 100) {\n weather += weather + \" Clear \";\n } else if (weatherCode == 200) {\n weather += weather + \" Partial clouds \";\n } else if (weatherCode == 300) {\n weather += weather + \" Cloudy \";\n } else if (weatherCode == 400) {\n weather += weather + \" Light Showers \";\n } else if (weatherCode == 500) {\n weather += weather + \" Heavy Showers \";\n } else if (weatherCode == 600) {\n weather += weather + \" Rain \";\n } else if (weatherCode == 700) {\n weather += weather + \" Snow \";\n } else if (weatherCode == 800) {\n weather += weather + \" Thunder \";\n } else {\n weather += weather + \" Partial clouds \";\n }\n }\n return weather;\n }", "java.lang.String getTransitAirportCity();", "public String getCurrentWeather() {\n\t\tString jsonStr = null;\n\t\t\n\t\tClient client = ClientBuilder.newClient();\t\t\n\t\tWebTarget target = client.target(OpenWeatherApiUtil.BASE_URL)\n\t\t\t\t.path(OpenWeatherApiUtil.WEATHER_RESOURCE)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.CITY_QUERY_PARAM, CITY_VANCOUVER)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.UNITS_QUERY_PARAM, OpenWeatherApiUtil.METRIC_UNITS)\n\t\t\t\t.queryParam(OpenWeatherApiUtil.API_KEY_QUERY_PARAM, getApiKey());\n\n\t\tLOG.debug(\"Target URL: \" + target.getUri().toString());\n\t\t\n\t\tInvocation.Builder invocationBuilder = target.request(MediaType.APPLICATION_JSON);\t\t\n\t\t\n\t\tResponse response = invocationBuilder.get(Response.class);\t\t\n\t\tjsonStr = response.readEntity(String.class);\n\t\t\n\t\t// Check response from Open Weather API and log the response appropriately\n\t\tif (response.getStatus() == 200) {\n\t\t\tLOG.debug(jsonStr);\n\t\t}\n\t\telse {\n\t\t\tLOG.error(ErrorMessageUtils.ERROR_OPEN_WEATHER_API_RESPONSE_NON_200_STATUS\n\t\t\t\t\t+ \"\\n\" + response.readEntity(String.class));\n\t\t}\n\t\t\t\n\t\treturn jsonStr;\n\t}", "private void requestWeatherTypes() {\n SharedPreferences preferences = getSharedPreferences(CommonConstants.APP_SETTINGS, MODE_PRIVATE);\n String url = \"https://api.openweathermap.org/data/2.5/forecast?\" +\n \"id=\" + input.get(CommonConstants.ARRIVAL_CITY_ID) +\n \"&appid=\" + CommonConstants.OWM_APP_ID +\n \"&lang=\" + Locale.getDefault().getLanguage() +\n \"&units=\" + preferences.getString(CommonConstants.TEMPERATURE_UNIT, \"Standard\");\n ForecastListener listener = new ForecastListener(weatherList -> {\n try {\n WeatherTypeMapper mapper = new WeatherTypeMapper();\n fillPreview(mapper.from(weatherList));\n if (input.containsKey(CommonConstants.SELECTIONS)) {\n //noinspection unchecked\n setSelections((List<Settings.Selection>) input.get(CommonConstants.SELECTIONS));\n }\n } catch (ExecutionException | InterruptedException e) {\n Log.e(TAG, \"onSuccess: \" + e.getMessage(), e);\n }\n });\n JsonObjectRequest request = new JsonObjectRequest(Request.Method.GET, url, null, listener, null);\n TravelRequestQueue.getInstance(this).addRequest(request);\n }", "@RequestMapping(value = \"/cityDetails\", method = RequestMethod.GET)\n public ResponseEntity<City> getCityDetails()\n {\n logger.info(\"Calling getCityDetails() method\");\n if(city.getCity() != null)\n {\n for (String item: city.getCity()\n ) {\n logger.debug(\"This are the cities \" + item);\n }\n }\n\n return new ResponseEntity<City>(city, HttpStatus.OK);\n }", "@GetMapping(\"/getByName/{cityName}\")\n public CityInfo getCityInfoByName(@PathVariable String cityName){\n return service.getByName(cityName);\n }", "List<City> getCityList(Integer countryId)throws EOTException;", "String getIPGeolocationCityDatabaseFile();", "@Override\n protected String[] doInBackground(String... params) {\n if (params.length == 0) {\n return null;\n }\n\n String location = params[0];\n URL weatherRequestUrl = NetworkUtils.buildUrl(location);\n\n try {\n String jsonWeatherResponse = NetworkUtils\n .getResponseFromHttpUrl(weatherRequestUrl);\n\n String[] simpleJsonWeatherData = OpenWeatherJsonUtils\n .getSimpleWeatherStringsFromJson(MainActivity.this, jsonWeatherResponse);\n\n return simpleJsonWeatherData;\n\n } catch (Exception e) {\n e.printStackTrace();\n return null;\n }\n }", "public void getCity(){\n }", "public abstract String getCity();", "public static String getXmlCode(String city) throws UnsupportedEncodingException {\n String requestUrl = \"http://api.map.baidu.com/weather/v1/?district_id=222405&data_type=all&ak=WCvM0jwmAi5N3ZmWmTadIUWjSCBzX4vb\"; //GET请求\n StringBuffer buffer = null;\n try {\n // 建立连接\n URL url = new URL(requestUrl);\n HttpURLConnection httpUrlConn = (HttpURLConnection) url.openConnection();\n httpUrlConn.setDoInput(true);\n httpUrlConn.setRequestMethod(\"GET\");\n // 获取输入流\n InputStream inputStream = httpUrlConn.getInputStream();\n InputStreamReader inputStreamReader = new InputStreamReader(inputStream, \"utf-8\");\n BufferedReader bufferedReader = new BufferedReader(inputStreamReader);\n // 读取返回结果\n buffer = new StringBuffer();\n String str = null;\n while ((str = bufferedReader.readLine()) != null) {\n buffer.append(str);\n }\n\n // 释放资源\n bufferedReader.close();\n inputStreamReader.close();\n inputStream.close();\n httpUrlConn.disconnect();\n } catch (Exception e) {\n e.printStackTrace();\n }\n return buffer.toString();\n }", "public LiveData<WeatherDetail> getWeatherInfo(double latitude, double longitude) {\n final MutableLiveData<WeatherDetail> data = new MutableLiveData<>();\n\n Call<WeatherDetail> call = apiInterface.getWeatherInfo(latitude, longitude, Const.WEATHER_API_KEY);\n call.enqueue(new Callback<WeatherDetail>() {\n @Override\n public void onResponse(Call<WeatherDetail> call, Response<WeatherDetail> response) {\n if (response.code() == 200)\n data.setValue(response.body());\n else {\n try {\n ErrorBody errorBody = errorConverter.convert(response.errorBody());\n data.postValue(new WeatherDetail(errorBody));\n } catch (IOException e) {\n e.printStackTrace();\n }\n }\n\n }\n\n @Override\n public void onFailure(Call<WeatherDetail> call, Throwable t) {\n data.postValue(new WeatherDetail(t));\n }\n });\n\n return data;\n }", "private void updateWeatherData(final String city){\n new Thread(){\n public void run(){\n final JSONObject json = WeatherJSON.getJSON(getActivity(), city);\n if(json != null){\n handler.post(new Runnable(){\n public void run(){\n renderWeather(json);\n }\n });\n } else {\n\n }\n }\n }.start();\n }", "@Override\n\tpublic Response weather(String iata, String radiusString) {\n\t\treturn null;\n\t}", "@Override\n public void requestWeatherSuccess(Weather weather, Location requestLocation) {\n try {\n if (request != null) {\n List<WeatherInfo.DayForecast> forecastList = new ArrayList<>();\n for (int i = 0; i < weather.dailyList.size(); i++) {\n forecastList.add(\n new WeatherInfo.DayForecast.Builder(\n WeatherConditionConvertHelper.getConditionCode(\n weather.dailyList.get(i).weatherKinds[0],\n true))\n .setHigh(weather.dailyList.get(i).temps[0])\n .setLow(weather.dailyList.get(i).temps[1])\n .build());\n }\n WeatherInfo.Builder builder = new WeatherInfo.Builder(\n weather.base.city,\n weather.realTime.temp,\n WeatherContract.WeatherColumns.TempUnit.CELSIUS)\n .setWeatherCondition(\n WeatherConditionConvertHelper.getConditionCode(\n weather.realTime.weatherKind,\n TimeManager.getInstance(this)\n .getDayTime(this, weather, false)\n .isDayTime()))\n .setTodaysHigh(weather.dailyList.get(0).temps[0])\n .setTodaysLow(weather.dailyList.get(0).temps[1])\n .setTimestamp(weather.base.timeStamp)\n .setHumidity(\n Double.parseDouble(\n weather.index.humidities[1]\n .split(\" : \")[1]\n .split(\"%\")[0]))\n .setWind(\n Double.parseDouble(weather.realTime.windSpeed.split(\"km/h\")[0]),\n weather.realTime.windDegree,\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH)\n .setForecast(forecastList);\n\n request.complete(new ServiceRequestResult.Builder(builder.build()).build());\n }\n } catch (Exception ignore) {\n requestWeatherFailed(requestLocation);\n }\n }", "String[] getRawWeatherDataByZipcode(String zipcode) throws JsonSyntaxException, Exception\n\t{\n\t\tfinal String urlHalf1 = \"http://api.openweathermap.org/data/2.5/weather?q=\";\n\t\tfinal String apiCode = \"&APPID=0bc46790fafd1239fff0358dc4cbe982\";\n\n\t\tString url = urlHalf1 + zipcode + \",us\" + apiCode;\n\n\t\tString[] weatherData = new String[4];\n\n\t\tJsonParser parser = new JsonParser();\n\n\t\tString hitUrl = url;\n\t\tString jsonData = getJsonData(hitUrl);\n\n\t\tJsonElement jsonTree = parser.parse(jsonData);\n\n\t\tif (jsonTree.isJsonObject())\n\t\t{\n\t\t\tJsonObject jsonObject = jsonTree.getAsJsonObject();\n\n\t\t\tJsonElement weather = jsonObject.get(\"weather\");\n\t\t\tJsonElement main = jsonObject.get(\"main\");\n\n\t\t\tif (weather.isJsonArray())\n\t\t\t{\n\t\t\t\tJsonArray weatherArray = weather.getAsJsonArray();\n\n\t\t\t\tJsonElement skyElement = weatherArray.get(0);\n\n\t\t\t\tif (skyElement.isJsonObject())\n\t\t\t\t{\n\t\t\t\t\tJsonObject skyObject = skyElement.getAsJsonObject();\n\n\t\t\t\t\tJsonElement skyData = skyObject.get(\"description\");\n\n\t\t\t\t\tweatherData[0] = skyData.getAsString();\n\t\t\t\t}\n\t\t\t}\n\n\t\t\tif (main.isJsonObject())\n\t\t\t{\n\t\t\t\tJsonObject mainToObject = main.getAsJsonObject();\n\t\t\t\tSystem.out.println(mainToObject.toString());\n\n\t\t\t\tJsonElement tempMin = mainToObject.get(\"temp_min\");\n\t\t\t\tJsonElement tempMax = mainToObject.get(\"temp_max\");\n\t\t\t\tJsonElement temp = mainToObject.get(\"temp\");\n\n\t\t\t\tweatherData[1] = tempMax.getAsString();\n\t\t\t\tweatherData[2] = tempMin.getAsString();\n\t\t\t\tweatherData[3] = temp.getAsString();\n\t\t\t}\n\t\t}\n\n\t\treturn weatherData;\n\t}", "void getForecastInitially(DarkSkyApi api, PlaceWeather weather){\n\n long newWeatherPlaceId = databaseInstance.weatherDao().insertPlaceWeather(weather);\n\n weather.getDaily().setParentPlaceId(newWeatherPlaceId);\n databaseInstance.weatherDao().insertDaily(weather.getDaily());\n\n List<DailyData> dailyData = weather.getDaily().getData();\n\n for(int i = 0; i < dailyData.size(); ++i){\n dailyData.get(i).setParentPlaceId(newWeatherPlaceId);\n dailyData.get(i).setId(\n databaseInstance.weatherDao().insertDailyData(dailyData.get(i))\n );\n }\n\n long currentDayId = dailyData.get(0).getId();\n\n weather.getHourly().setParentDayId(currentDayId);\n databaseInstance.weatherDao().insertHourly(weather.getHourly());\n\n List<HourlyData> hourlyData = weather.getHourly().getData();\n\n for(int i = 0; i < hourlyData.size(); ++i){\n hourlyData.get(i).setParentDayId(currentDayId);\n databaseInstance.weatherDao().insertHourlyData(hourlyData.get(i));\n }\n\n //now load hours of next 7 days initially\n String apiKey = context.getString(R.string.api_key);\n Map<String, String> avoid = new HashMap<>();\n avoid.put(\"units\", \"si\");\n avoid.put(\"lang\", \"en\");\n avoid.put(\"exclude\", \"alerts,daily\");\n\n\n PlaceWeather dayWeather;\n for(int i = 1; i < dailyData.size(); ++i){\n try{\n dayWeather = api.getTimeForecast(apiKey,\n weather.getLatitude(),\n weather.getLongitude(),\n dailyData.get(i).getTime()+1,\n avoid).execute().body();\n }catch (IOException e){\n break;\n }\n\n dayWeather.getHourly().setParentDayId(dailyData.get(i).getId());\n dayWeather.getHourly().setId(\n databaseInstance.weatherDao().insertHourly(dayWeather.getHourly())\n );\n\n hourlyData = dayWeather.getHourly().getData();\n\n for(int j = 0; j < hourlyData.size(); ++j){\n hourlyData.get(j).setParentDayId(dailyData.get(i).getId());\n databaseInstance.weatherDao().insertHourlyData(hourlyData.get(j));\n }\n }\n\n }" ]
[ "0.7750773", "0.755098", "0.7469178", "0.7225847", "0.7171399", "0.7113883", "0.704045", "0.6981611", "0.6960313", "0.6864307", "0.6825277", "0.6818141", "0.68099564", "0.67588216", "0.67422473", "0.66869485", "0.66414005", "0.66309565", "0.66273624", "0.6619802", "0.6618427", "0.65973794", "0.6568273", "0.6564296", "0.65592283", "0.6543666", "0.65205675", "0.65070254", "0.64701325", "0.6435934", "0.6433803", "0.6410945", "0.64076644", "0.638738", "0.6368084", "0.6356173", "0.6340102", "0.6340005", "0.6328633", "0.6306648", "0.6301447", "0.6300318", "0.6287533", "0.62776273", "0.6267101", "0.6244399", "0.6228515", "0.6212269", "0.6211686", "0.62026185", "0.61936146", "0.6160652", "0.61570764", "0.61369294", "0.6129404", "0.6124717", "0.61232626", "0.6119021", "0.6080906", "0.60807574", "0.60399044", "0.5998248", "0.59948546", "0.5984701", "0.59771603", "0.59684765", "0.59583277", "0.59493846", "0.59438664", "0.593433", "0.59332436", "0.58919406", "0.58692163", "0.5864397", "0.58489436", "0.58358884", "0.583482", "0.58345383", "0.5832433", "0.5828961", "0.5826998", "0.5824362", "0.5821362", "0.5816741", "0.5816144", "0.58115345", "0.57882017", "0.5773055", "0.5769425", "0.5765653", "0.57561386", "0.5755384", "0.5753621", "0.5732763", "0.5729713", "0.5709063", "0.56974226", "0.5689091", "0.56890005", "0.56818956" ]
0.6267888
44
compare weather temperature from UI and API Return success if temp difference is less than 2
@Test(priority = 6) public void compare_Weather_Data() { Comparator.userCompareVariation(weatherMap.get("Temperature").toString(), weatherResponse_city.getJSONObject("main").get("temp").toString()); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public double getWeatherAPI() {\n\t\tRestAssured.baseURI= props.getProperty(\"BaseURI\");\n\t\tString response = \tgiven().log().all().header(\"Content-Type\",\"application/json\").\n\t\t\t\tqueryParam(\"q\", props.getProperty(\"city\")).\n\t\t\t\tqueryParam(\"appid\", props.getProperty(\"key\")).\n\t\t\t\tqueryParam(\"units\", props.getProperty(\"unit\"))\n\t\t\t\t.when().get(\"data/2.5/weather\")\n\t\t\t\t.then().log().all().assertThat().statusCode(200).header(\"charset\", \"UTF-8\").extract().response().asString();\n\n\n\t\tSystem.out.println(response);\n\n\t\tJsonPath json = new JsonPath(response); // parsing the String response to Json\n\t\tString temp = json.getString(\".main.temp\");\n\t\tSystem.out.println(temp);\n\t\t\n\t\tdouble tempurature = Double.parseDouble(temp);\n\t\t\n\t\treturn tempurature;\n\t\t\n\t\t\n\t\t\n\t}", "private void openRealTemp() {\n YCBTClient.appTemperatureMeasure(0x01, new BleDataResponse() {\n @Override\n public void onDataResponse(int i, float v, HashMap hashMap) {\n if (i == 0) {\n //success\n }\n }\n });\n }", "public static boolean compareTempValues(String city) {\n try {\n List<Long> web = getWebTempValues(city).stream().map(Math::round).collect(Collectors.toList());\n List<Long> api = getAPITempValues().stream().map(Math::round).collect(Collectors.toList());\n return web.equals(api);\n } catch (Exception e) {\n return false;\n }\n }", "private double measureTemp() {\n try {\n analog0 = blueTooth.sensor(0);\n analog1 = blueTooth.sensor(1);\n return ((analog0 - analog1) * 5 * 100) / 1024.0;\n } catch (TimeoutException ex) {\n Logger.getLogger(TempMeasure.class.getName()).log(Level.SEVERE, null, ex);\n }\n return ((analog0 - analog1) * 5 * 100) / 1024.0;\n }", "private static boolean anomalyCheck(double oldtemperature, double temperature2) {\n\t\tif (Math.abs(oldtemperature-temperature2)>=10)\n\t\t\treturn true;\n\t\telse \n\t\t\treturn false;\n\t\t\n\t}", "private void getTemperatureAndHumidity() {\n // Get Temp and Humid sensors only at PM10 locations, otherwise\n // the connection takes too long to load all\n for (Sensor pm10sensor : this.sensorsPm10) {\n this.sensorsTempHumid.addAll(\n this.getSensors(\n this.readHTML(\n this.buildURLTempHumid(\n pm10sensor.getLatLng()))));\n }\n }", "float getTemperature();", "@Test\n\tpublic void testGetValue() {\n\n\t\tTemperature belowMinTemp;\n\t\tTemperature minimumTemp;\n\t\tTemperature averageTemp;\n\n\t\tfinal double THRESHOLD = 1e-6; // maximum allowable error\n\n\t\t// Celsius\n\t\ttry {\n\t\t\tbelowMinTemp = new Temperature(-273.16, Temperature.Units.CELSIUS);\n\t\t} catch (IllegalArgumentException ex) {\n\t\t\tassertTrue(\"Cannot have celsius lower than -273.15\",\n\t\t\t\t\tex instanceof IllegalArgumentException);\n\t\t}\n\t\tminimumTemp = new Temperature(-273.15, Temperature.Units.CELSIUS);\n\t\taverageTemp = new Temperature(33.3333, Temperature.Units.CELSIUS);\n\n\t\tassertTrue(\"Minimum Celsius should be -273.15\",\n\t\t\t\tminimumTemp.getValue() == -273.15);\n\t\tassertEquals(\"An average temperature in Celsius\", 33.3333,\n\t\t\t\taverageTemp.getValue(), THRESHOLD);\n\n\t\t// Fahrenheit\n\t\ttry {\n\t\t\tbelowMinTemp = new Temperature(-459.68,\n\t\t\t\t\tTemperature.Units.FAHRENHEIT);\n\t\t} catch (IllegalArgumentException ex) {\n\t\t\tassertTrue(\"Cannot have fahrenheit below -459.67\",\n\t\t\t\t\tex instanceof IllegalArgumentException);\n\t\t}\n\t\tminimumTemp = new Temperature(-459.67, Temperature.Units.FAHRENHEIT);\n\t\taverageTemp = new Temperature(99.9999, Temperature.Units.FAHRENHEIT);\n\n\t\tassertTrue(\"Minimum Fahrenheit should be -459.67\",\n\t\t\t\tminimumTemp.getValue() == -459.67);\n\t\tassertEquals(\"An average temperature in Celsius\", 99.9999,\n\t\t\t\taverageTemp.getValue(), THRESHOLD);\n\n\t\t// Kelvin\n\t\ttry {\n\t\t\tbelowMinTemp = new Temperature(-0.00001, Temperature.Units.KELVIN);\n\t\t} catch (IllegalArgumentException ex) {\n\t\t\tassertTrue(\"Cannot have negative kelvin\",\n\t\t\t\t\tex instanceof IllegalArgumentException);\n\t\t}\n\t\tminimumTemp = new Temperature(0, Temperature.Units.KELVIN);\n\t\taverageTemp = new Temperature(300, Temperature.Units.KELVIN);\n\n\t\tassertTrue(\"Minimum Kelvin should be zero\", minimumTemp.getValue() == 0);\n\t\tassertEquals(\"An average temperature in Kelvin\", 300,\n\t\t\t\taverageTemp.getValue(), THRESHOLD);\n\n\t}", "public static String check() {\n\t\ttry {\n\t\t\tString status = null;\n\t\t\t// Envia uma solicitacao de variavel para o ESP32\n\t\t\tSystem.out.print(\"Enviando Request ao ESP32... \");\n \t \tHttpClient client = HttpClient.newHttpClient();\n HttpRequest request = HttpRequest.newBuilder() // Request para atualizar a valor do sensor \n .uri(URI.create(\"http://\" + ESP32IP + \"/checkLight\")) \n .build();\n HttpRequest request2 = HttpRequest.newBuilder() // Request para retornar o valor do sensor\n .uri(URI.create(\"http://\" + ESP32IP + \"/Light\")) \n .build();\n HttpResponse<String> response = client.send(request,\n \t\t\tHttpResponse.BodyHandlers.ofString());\n HttpResponse<String> response2 = client.send(request2,\n \t\t\tHttpResponse.BodyHandlers.ofString());\n \n System.out.println(\"Pronto!\");\n \n // Organiza a resposta em JSON\n Gson gson = new Gson();\n ReturnValues Jresponse = gson.fromJson(response.body(), ReturnValues.class);\n \n // Verifica a variavel e exibe a resposta\n if(Jresponse.getLight()) {\n \tstatus = \"On\";\n \tSystem.out.println(\"A luz esta ligada\");\n } else if(!Jresponse.getLight()) {\n \tstatus = \"Off\";\n \tSystem.out.println(\"A luz esta desligada\");\n } else {\n \tstatus = \"Erro\";\n \tSystem.out.println(\"Nao foi possivel reconhecer o estado da luz\");\n }\n return status;\n } catch (Exception e) {\n \t System.out.printf(\"\\n Nao foi possivel conectar ao ESP32\");\n \t // e.printStackTrace();\n \t return \"Erro\";\n }\n\t}", "public String getCurrentTempInVancouver() throws IOException, JSONException {\n JSONObject json = readJsonFromUrl(theURL);\n JSONObject main = (JSONObject) json.get(\"main\");\n double kelvinD = 987654;\n int kelvinI = 987654;\n double c;\n try {\n kelvinD = (Double) main.get(\"temp\");\n } catch (ClassCastException e) {\n kelvinI = (Integer) main.get(\"temp\");\n }\n if (kelvinD != 987654) {\n c = kelvinD - 273.15;\n } else {\n c = kelvinI - 273.15;\n }\n double ccOneDecimal = Math.round(c * 10) / 10.0;\n return ccOneDecimal + \"°C\";\n }", "private void closeRealTemp() {\n YCBTClient.appTemperatureMeasure(0x00, new BleDataResponse() {\n @Override\n public void onDataResponse(int i, float v, HashMap hashMap) {\n if (i == 0) {\n //success\n }\n }\n });\n }", "@SneakyThrows\n String getTemperature(String city) throws MalformedURLException, IOException {\n double current_temperature = 0;\n JSONObject json = new JSONObject(IOUtils.toString(new URL(\"https://api.openweathermap.org/data/2.5/weather?q=\" + city.toLowerCase(Locale.ROOT) + \"&appid=\"), Charset.forName(\"UTF-8\")));\n current_temperature = (Float.parseFloat(json.getJSONObject(\"main\").get(\"temp\").toString()));\n current_temperature = Math.round(current_temperature*100.0)/100.0;\n System.out.println(json);\n return current_temperature + \"\";\n }", "void update(double temperature, double maxTemperature, double minTemperature, int humidity);", "private static void performDiff(Temperature t, double tempReading, char scale)\n {\n Temperature temp; // the temperature to be compared with\n \n if (scale == CEL_SCALE_CODE) { \n temp = new Temperature(tempReading, true);\n }\n else if (scale == FAH_SCALE_CODE) { \n temp = new Temperature(tempReading, false);\n }\n else {\n temp = new Temperature(tempReading);\n }\n\n System.out.printf(\"Computing difference between %s (%s) and %s (%s)\\n\", \n t.toString(), t.toString(false), \n temp.toString(), temp.toString(false));\n double diffCel1 = t.difference(temp, true);\n System.out.printf(\" difference(%s, true) yields %f\\n\", temp, diffCel1);\n double diffFah = t.difference(temp, false);\n System.out.printf(\" difference(%s, false) yields %f\\n\", temp, diffFah);\n double diffCel2 = t.difference(temp);\n System.out.printf(\" difference(%s) yields %f\\n\", temp, diffCel2);\n }", "public static double getTemperature(String weatherInfos) {\n\t\tMap<String, Object> respMap = jsonToMap(weatherInfos.toString());\n\t\tMap<String, Object> mainMap = jsonToMap(respMap.get(\"main\").toString());\n\t\t\n\t\tObject temp = mainMap.get(\"temp\");\n\t\t\n\t\tdouble temperatureInKelvin = (double)temp;\n\t\t\n\t\tdouble temperatureInCelsius = convertKelvinToCelsius(temperatureInKelvin);\n\t\tdouble rounded = BigDecimal.valueOf(temperatureInCelsius)\n\t\t\t\t.setScale(2, RoundingMode.HALF_UP)\n\t\t\t\t.doubleValue();\n\t\treturn rounded;\n\n\t}", "public BrickletTemperatureIR(String uid, IPConnection ipcon) {\n\t\tsuper(uid, ipcon);\n\n\t\tapiVersion[0] = 2;\n\t\tapiVersion[1] = 0;\n\t\tapiVersion[2] = 0;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_AMBIENT_TEMPERATURE)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_OBJECT_TEMPERATURE)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_EMISSIVITY)] = RESPONSE_EXPECTED_FLAG_FALSE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_EMISSIVITY)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_AMBIENT_TEMPERATURE_CALLBACK_PERIOD)] = RESPONSE_EXPECTED_FLAG_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_AMBIENT_TEMPERATURE_CALLBACK_PERIOD)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_OBJECT_TEMPERATURE_CALLBACK_PERIOD)] = RESPONSE_EXPECTED_FLAG_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_OBJECT_TEMPERATURE_CALLBACK_PERIOD)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_AMBIENT_TEMPERATURE_CALLBACK_THRESHOLD)] = RESPONSE_EXPECTED_FLAG_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_AMBIENT_TEMPERATURE_CALLBACK_THRESHOLD)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_OBJECT_TEMPERATURE_CALLBACK_THRESHOLD)] = RESPONSE_EXPECTED_FLAG_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_OBJECT_TEMPERATURE_CALLBACK_THRESHOLD)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_SET_DEBOUNCE_PERIOD)] = RESPONSE_EXPECTED_FLAG_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_DEBOUNCE_PERIOD)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(FUNCTION_GET_IDENTITY)] = RESPONSE_EXPECTED_FLAG_ALWAYS_TRUE;\n\t\tresponseExpected[IPConnection.unsignedByte(CALLBACK_AMBIENT_TEMPERATURE)] = RESPONSE_EXPECTED_FLAG_ALWAYS_FALSE;\n\t\tresponseExpected[IPConnection.unsignedByte(CALLBACK_OBJECT_TEMPERATURE)] = RESPONSE_EXPECTED_FLAG_ALWAYS_FALSE;\n\t\tresponseExpected[IPConnection.unsignedByte(CALLBACK_AMBIENT_TEMPERATURE_REACHED)] = RESPONSE_EXPECTED_FLAG_ALWAYS_FALSE;\n\t\tresponseExpected[IPConnection.unsignedByte(CALLBACK_OBJECT_TEMPERATURE_REACHED)] = RESPONSE_EXPECTED_FLAG_ALWAYS_FALSE;\n\n\t\tcallbacks[CALLBACK_AMBIENT_TEMPERATURE] = new CallbackListener() {\n\t\t\tpublic void callback(byte[] data) {\n\t\t\t\tByteBuffer bb = ByteBuffer.wrap(data, 8, data.length - 8);\n\t\t\t\tbb.order(ByteOrder.LITTLE_ENDIAN);\n\n\t\t\t\tshort temperature = (bb.getShort());\n\n\t\t\t\tfor(AmbientTemperatureListener listener: listenerAmbientTemperature) {\n\t\t\t\t\tlistener.ambientTemperature(temperature);\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\n\t\tcallbacks[CALLBACK_OBJECT_TEMPERATURE] = new CallbackListener() {\n\t\t\tpublic void callback(byte[] data) {\n\t\t\t\tByteBuffer bb = ByteBuffer.wrap(data, 8, data.length - 8);\n\t\t\t\tbb.order(ByteOrder.LITTLE_ENDIAN);\n\n\t\t\t\tshort temperature = (bb.getShort());\n\n\t\t\t\tfor(ObjectTemperatureListener listener: listenerObjectTemperature) {\n\t\t\t\t\tlistener.objectTemperature(temperature);\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\n\t\tcallbacks[CALLBACK_AMBIENT_TEMPERATURE_REACHED] = new CallbackListener() {\n\t\t\tpublic void callback(byte[] data) {\n\t\t\t\tByteBuffer bb = ByteBuffer.wrap(data, 8, data.length - 8);\n\t\t\t\tbb.order(ByteOrder.LITTLE_ENDIAN);\n\n\t\t\t\tshort temperature = (bb.getShort());\n\n\t\t\t\tfor(AmbientTemperatureReachedListener listener: listenerAmbientTemperatureReached) {\n\t\t\t\t\tlistener.ambientTemperatureReached(temperature);\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\n\t\tcallbacks[CALLBACK_OBJECT_TEMPERATURE_REACHED] = new CallbackListener() {\n\t\t\tpublic void callback(byte[] data) {\n\t\t\t\tByteBuffer bb = ByteBuffer.wrap(data, 8, data.length - 8);\n\t\t\t\tbb.order(ByteOrder.LITTLE_ENDIAN);\n\n\t\t\t\tshort temperature = (bb.getShort());\n\n\t\t\t\tfor(ObjectTemperatureReachedListener listener: listenerObjectTemperatureReached) {\n\t\t\t\t\tlistener.objectTemperatureReached(temperature);\n\t\t\t\t}\n\t\t\t}\n\t\t};\n\t}", "private int syncWeatherData() throws IOException {\n URL carleton = null;\n try {\n carleton = new URL(\"http://weather.carleton.edu\");\n } catch (MalformedURLException e) {\n e.printStackTrace();\n Log.i(\"syncWeatherData\", \"malformed URL for carleton weather\");\n return -1;\n }\n BufferedReader in = null;\n try {\n in = new BufferedReader(\n new InputStreamReader(carleton.openStream()));\n } catch (IOException e) {\n e.printStackTrace();\n Log.i(\"syncWeatherData\", \"openSteam IOException for carleton weather\");\n return -1;\n }\n String inputLine;\n int lineNum = 0;\n String speedString = new String();\n String tempString = new String();\n try {\n while ((inputLine = in.readLine()) != null){\n if (lineNum == 126) {\n tempString = inputLine;\n }\n else if (lineNum == 152) {\n speedString = inputLine;\n }\n lineNum++;\n }\n in.close();\n } catch (IOException e) {\n e.printStackTrace();\n Log.i(\"syncWeatherData\", \"parsing IOException for carleton weather\");\n return -1;\n }\n double temp = parseHTMLForTemp(tempString);\n int speed = parseHTMLForSpeed(speedString);\n\n currentTemperature = temp;\n currentWindspeed = speed;\n SharedPreferences sharedPref = context.getSharedPreferences(PREFS_NAME, Context.MODE_PRIVATE);\n SharedPreferences.Editor e = sharedPref.edit();\n e.putFloat(\"currentTemperature\", (float)currentTemperature);\n e.putFloat(\"currentWindspeed\", (float)currentWindspeed);\n e.commit();\n return 0;\n\n }", "public double convertor(double temperature) {\n\t\t// Create the locator object to locate the server\n\t\tFahrenheitToCelsiusServiceLocator locatorObject = new FahrenheitToCelsiusServiceLocator();\n\t\tdouble result = 0;\n\t\t// setting the locator end point address\n\t\tlocatorObject.setFahrenheitToCelsiusEndpointAddress(\"http://localhost:8080/com.metacube.SoapServer/services/FahrenheitToCelsius\");\n\t\ttry {\n\t\t\tFahrenheitToCelsius temperatureConversion = locatorObject.getFahrenheitToCelsius();\n\t\t\tresult = temperatureConversion.convertFahrenheitToCelsius(temperature);\n\t\t} catch (ServiceException | RemoteException e) {\n\t\t\tSystem.out.println(\"Error in connection.\");\n\t\t} catch (Exception e) {\n\t\t\tSystem.out.println(\"Error occured.\");\n\t\t}\n\t\treturn result;\n\t}", "public static String findTemp(String lat, String lon) {\n //final String methodPath = \"/entities.electricityusage/\";\n //initialize\n URL url = null;\n String appid = \"appid=f93bd59bea3ab44fb8dba0d95596adfc\";\n HttpURLConnection conn = null;\n String textResult = \"\";\n //making http request\n try {\n url = new URL(WEATHER_URI + \"lat=\" + lat + \"&\" + \"lon=\" + lon + \"&\" +appid);\n // open the connection\n conn = (HttpURLConnection) url.openConnection();\n // set the time out\n conn.setReadTimeout(10000);\n conn.setConnectTimeout(15000);\n // set the connection method to GET\n conn.setRequestMethod(\"GET\");\n //add http headers to set your response type to json\n conn.setRequestProperty(\"Content-Type\", \"application/json\");\n conn.setRequestProperty(\"Accept\", \"application/json\");\n //Read the response\n Scanner inStream = new Scanner(conn.getInputStream());\n //read the input stream and store it as string\n while (inStream.hasNextLine()) {\n textResult += inStream.nextLine();\n }\n\n } catch (Exception e) {\n e.printStackTrace();\n } finally {\n conn.disconnect();\n }\n return textResult;\n }", "private void readRealTemp() {\n YCBTClient.getRealTemp(new BleDataResponse() {\n @Override\n public void onDataResponse(int i, float v, HashMap hashMap) {\n if (i == 0) {\n String temp = (String) hashMap.get(\"tempValue\");\n }\n }\n });\n }", "public double getTemperature() {return temperature;}", "double getTempo();", "protected void onGetMeasuredRoomTemperature(EchoObject eoj, short tid, byte esv, EchoProperty property, boolean success) {}", "@Test\n public void shouldReturnMinimumAmbientAirTemperature() {\n\n Integer testInput = 0;\n Integer expectedValue = -40;\n \n AmbientAirTemperature testAmbientAirTemperature = new AmbientAirTemperature(testInput);\n AmbientAirPressure testAmbientAirPressure = new AmbientAirPressure(0);\n \n WeatherProbe testWeatherProbe = new WeatherProbe(\n testAmbientAirTemperature,\n testAmbientAirPressure,\n mockWiperSet);\n \n Integer actualValue = OssWeatherProbe.genericWeatherProbe(testWeatherProbe).getAirTemp();\n \n assertEquals(expectedValue, actualValue);\n \n }", "FloatResource temperatureCoefficient();", "public static WeatherInfo extractWeather(String response) {\n JsonParser parser = new JsonParser();\n JsonElement jsonElement = parser.parse(response);\n JsonObject rootObject = jsonElement.getAsJsonObject();\n JsonObject location = rootObject.getAsJsonObject(\"location\");\n String city = location.get(\"name\").getAsString();\n String country = location.get(\"country\").getAsString();\n JsonObject current = rootObject.getAsJsonObject(\"current\");\n Double temp = current.get(\"temp_c\").getAsDouble();\n JsonObject condition = current.getAsJsonObject(\"condition\");\n String conditionText = condition.get(\"text\").getAsString();\n return new WeatherInfo(city, country, conditionText, temp);\n}", "private void calculateInitialAndFinalTemperature(){\n double maxSolutionValueDifference = 0;\n double minSolutionValueDifference = 0;\n double solutionValueDifference = 0;\n ArrayList<int[]> neighbours = getAllNeighbours(getInitialSolution());\n\n for(int i = 0; i <= neighbours.size() - 1; i++){\n for(int j = 0; j <= neighbours.size() - 1; j++){\n if(i != j){\n solutionValueDifference = getSolutionDifference(neighbours.get(i), neighbours.get(j));\n\n if((maxSolutionValueDifference == 0) && (minSolutionValueDifference == 0)){\n maxSolutionValueDifference = solutionValueDifference;\n minSolutionValueDifference = solutionValueDifference;\n }\n\n if(solutionValueDifference > maxSolutionValueDifference){\n maxSolutionValueDifference = solutionValueDifference;\n }\n else{\n if((solutionValueDifference > 0) && (solutionValueDifference < minSolutionValueDifference)){\n minSolutionValueDifference = solutionValueDifference;\n }\n }\n }\n }\n }\n\n this.initialTemperature = maxSolutionValueDifference;\n this.finalTemperature = minSolutionValueDifference;\n }", "@Override\n protected String doInBackground(String... strings) {\n String stringUrl = \"http://api.openweathermap.org/data/2.5/forecast?q=Chongqing,cn&mode=json&APPID=aa3d744dc145ef9d350be4a80b16ecab\";\n HttpURLConnection urlConnection = null;\n BufferedReader reader;\n try {\n URL url = new URL(stringUrl);\n\n // Create the request to get the information from the server, and open the connection\n urlConnection = (HttpURLConnection) url.openConnection();\n urlConnection.setRequestMethod(\"GET\");\n urlConnection.connect();\n\n // Read the input stream into a String\n InputStream inputStream = urlConnection.getInputStream();\n StringBuffer buffer = new StringBuffer();\n if (inputStream == null) {\n // Nothing to do.\n return null;\n }\n reader = new BufferedReader(new InputStreamReader(inputStream));\n String line;\n while ((line = reader.readLine()) != null) {\n // Mainly needed for debugging\n buffer.append(line + \"\\n\");\n }\n if (buffer.length() == 0) {\n // Stream was empty. No point in parsing.\n return null;\n }\n //Parse JSON data\n try{\n JSONObject jsonObj = new JSONObject(buffer.toString());\n String list = jsonObj.optString(\"list\").toString();\n String city = jsonObj.optString(\"city\").toString();\n JSONObject cityObj = new JSONObject(city);\n city_name = cityObj.optString(\"name\");\n\n //There are arrays in list\n JSON_Array = new JSONArray(list);\n\n //Get the current temperature in the array which index is 0\n int[][] array = new int[5][8];\n for(int j=0; j<5; j++){\n for(int i=0; i<8; i++)\n array[j][i] = getTemperature(JSON_Array,i+8*j);\n bubbleSort(array[j]);\n }\n /*for(int i=0; i<6; i++)\n array[4][i] = getTemperature(JSON_Array,i+8*j);\n bubbleSort(array[4]);*/\n\n secondTemp = String.valueOf(array[1][0]) + \"~\" + String.valueOf(array[1][7]) + \"°C\";\n thirdTemp = String.valueOf(array[2][0]) + \"~\" + String.valueOf(array[2][7]) + \"°C\";\n fourthTemp = String.valueOf(array[3][0]) + \"~\" + String.valueOf(array[3][7]) + \"°C\";\n fifthTemp = String.valueOf(array[4][3]) + \"~\" + String.valueOf(array[4][7]) + \"°C\";\n\n String currentTemp = String.valueOf(array[0][0]) + \"~\" + String.valueOf(array[0][7]);\n return currentTemp;\n }catch (JSONException e){\n e.printStackTrace();\n }\n //return result;//return the data of temperature.\n } catch (MalformedURLException e) {\n e.printStackTrace();\n } catch (ProtocolException e) {\n e.printStackTrace();\n } catch (IOException e) {\n e.printStackTrace();\n }\n return null;\n }", "public LongTermForecast(JSONObject j, char tempUnits){\n \n /*Set sub-JSONObjects\n *OpenWeatherMap returns a large JSONObject that contains multiple\n *smaller JSONObjects; we get these during this step\n */\n \ttry{\n this.jCity = j.getJSONObject(\"city\");\n this.jListArray = j.getJSONArray(\"list\");\n this.jTempList = new ArrayList<JSONObject>();\n this.jWeatherList = new ArrayList<JSONObject>();\n int dateOffset = 0; // <--- To exclude the current day, change this to 1\n for (int i = dateOffset; i < 5 + dateOffset; i++) \n {\n JSONObject nextObject = jListArray.getJSONObject(i);\n this.jTempList.add(nextObject.getJSONObject(\"temp\"));\n this.jWeatherList.add(nextObject.getJSONArray(\"weather\").getJSONObject(0));\n }\n this.tempUnits = tempUnits;\n\n \n //Set the variable values based on the JSON data\n this.fullCityName = getFullCityName(jCity);\n this.temperatureList = new ArrayList<String>();\n this.minTempList = new ArrayList<String>();\n this.maxTempList = new ArrayList<String>();\n this.skyConditionList = new ArrayList<String>();\n this.skyIconList = new ArrayList<ImageIcon>();\n this.dateList = new ArrayList<String>();\n for (int i = 0; i < 5; i++)\n {\n JSONObject nextTemp = jTempList.get(i);\n JSONObject nextWeather = jWeatherList.get(i);\n this.temperatureList.add(getTemperature(nextTemp));\n this.minTempList.add(getMinTemp(nextTemp));\n this.maxTempList.add(getMaxTemp(nextTemp));\n this.skyConditionList.add(getSkyCondition(nextWeather));\n try{\n this.skyIconList.add(getSkyIcon(nextWeather));\n }\n catch(IOException e){\n System.out.println(\"Error: Can't obtain sky icon\");\n }\n this.dateList.add(getDate(jListArray, i + dateOffset));\n }\n \t} catch (Exception e){\n\t\t\tthis.temperatureList = new ArrayList<String>();\n\t\t\tthis.skyConditionList = new ArrayList<String>();\n\t\t\tthis.skyIconList = new ArrayList<ImageIcon>();\n\t\t\tthis.minTempList = new ArrayList<String>();\n\t\t\tthis.maxTempList = new ArrayList<String>();\n\t this.dateList = new ArrayList<String>();\n\t\t\tfor (int i = 0; i < 8; i++)\n\t\t\t{\n\t\t\t\tthis.minTempList.add(\"No Data \");\n\t\t\t\tthis.maxTempList.add(\"No Data \");\n\t\t\t\tthis.temperatureList.add(\"No Data \");\n\t\t\t\tthis.dateList.add(\"No Data \");\n\t\t\t\ttry {\n\t\t\t\t\tthis.skyIconList.add(getSkyIcon(new JSONObject(\"{icon:01d}\")));\n\t\t\t\t} catch (JSONException e1) {\n\t\t\t\t\te1.printStackTrace();\n\t\t\t\t} catch (IOException e1) {\n\t\t\t\t\te1.printStackTrace();\n\t\t\t\t}\n\t\t\t\tthis.skyConditionList.add(\"No Data \");\n\t\t\t} \n\t\t}\n\n }", "@RequestMapping(\"/temperature\")\n public TemperatureResponse temperature() {\n LOG.info(\"Reading temperature\");\n TemperatureResponse response = new TemperatureResponse();\n response.setHost(getHostname());\n response.setTemperature(getTemperature());\n return response;\n }", "public static void main(String[] args) {\r\n\r\n\t\tint firstTemp = 154;\r\n\t\tint secondTemp = -54;\r\n\t\t\r\n\t\tSystem.out.println(checkTemp(firstTemp, secondTemp));\r\n\r\n\t}", "private void getTemperature() {\r\n \t\r\n \t//Get the date from the DateService class\r\n \tDate theDate = theDateService.getDate(); \r\n \t\r\n \t//Increment the number of readings\r\n \tlngNumberOfReadings ++;\r\n \tdouble temp = 0.0;\r\n \tString rep = \"\";\r\n \t\r\n \t//Assume that the TMP36 is connected to AIN4\r\n \trep = this.theTemperatureService.readTemperature(\"4\");\r\n \tpl(rep);\r\n \ttemp = this.theTemperatureService.getTheTemperature();\r\n \t\r\n \t//All details necessary to send this reading are present so create a new TemperatureReading object\r\n \tTemperatureReading theReading = new TemperatureReading(temp, theDate, lngNumberOfReadings);\r\n \tthis.send(theReading);\r\n \t\r\n }", "private double calculA(double temperature) {\n int indice;\n String ts;\n String as;\n double t1 = 0;\n double t2 = 0;\n double a1 = 0;\n double a2 = 0;\n String line;\n\n try {\n BufferedReader lecture = new BufferedReader(new InputStreamReader(\n getClass().getResourceAsStream(taFile)));\n\n while (((line = lecture.readLine()) != null) && (line != \"\") && \n (t2 < temperature)) {\n indice = line.indexOf(\",\"); \n ts = line.substring(0, indice);\n as = line.substring(indice + 1, line.length());\n\n try {\n t2 = Double.parseDouble(ts);\n a2 = Double.parseDouble(as);\n } catch (NumberFormatException exce) {\n }\n\n ;\n\n if (t2 < temperature) {\n t1 = t2;\n a1 = a2;\n }\n }\n } catch (IOException e) {\n }\n\n if (t2 > temperature) {\n return a1 + (((a2 - a1) * (temperature - t1)) / (t2 - t1));\n } else {\n return a2;\n }\n }", "private static void getWeatherDataForInputValues(BigDecimal lat, BigDecimal lon) throws RemoteException{\n\t\t\n\t\tCalendar time = new GregorianCalendar();\t\t\t\t// Pass this as a GregorianCalendar for the Calendar to understand\n\t\ttime.setTime(new Date());\n\t\tSystem.out.println(\"Fetaching data from SOAP Web Service... Please wait\");\n\t\tString result = proxy.NDFDgen(lat,lon,\"time-series\",time,time,\"e\",wp);\n\t\tDocument dom= convertStringToDocument(result);\n\t\ttry{\n\t\t\t//Displaying the result on the output screen\n\t\t\tXPathFactory xpathFactory = XPathFactory.newInstance();\n\t\t\tXPath xpath = xpathFactory.newXPath();\n\t\t\tSystem.out.println(\"Minimum Temperature: \"+getValuesFromDom(dom,xpath,\"temperature[@type='minimum']\")); //print the minimum temp\n\t\t\tSystem.out.println(\"Maximum Temperature: \"+getValuesFromDom(dom,xpath,\"temperature[@type='maximum']\")); // print the maximum temp\n\t\t\tSystem.out.println(\"Wind Direction: \"+getValuesFromDom(dom,xpath,\"direction\")); // print the wind direction\n\t\t\tSystem.out.println(\"Wind Speed: \"+getValuesFromDom(dom,xpath,\"wind-speed\")); // print the wind speed\n\t\t\tSystem.out.println(\"Temperature Dew point: \"+getValuesFromDom(dom,xpath,\"temperature[@type='dew point']\")); // print the dew point temperature\n\t\t\tSystem.out.println(\"12 Hour Probability of Precipitation:\"+getValuesFromDom(dom,xpath,\"probability-of-precipitation\"));\n\t\t\tString command = isRefreshed();\n\t\t\tif(command.trim().toLowerCase().equals(\"yes\")){\n\t\t\t\t\n\t\t\t\tgetWeatherDataForInputValues(lat,lon);\n\t\t\t}\n\t\t\t\n\t\t}catch(Exception e) {\n\t\t\te.printStackTrace();\n\t\t}\n\t}", "@Test\n\t@Title(\"TC_008: Verify that the current weather data is returned correctly when user search for the City Name\")\n\t \n\tpublic void TC_008_Verify_CurrentWeatherInfo_Is_Returned_For_ValidCity() {\n\t\t\n\t\tLocation city = new Location();\n\t\t\n\t\tcity = DataReader.RetrieveLocationFromFile(\"data.json\").get(0);\n\t\t\n\t\tcity.weather = new Weather(\"C\");\n\t\t\n\t\t//Steps:\n\t\t//1. Access to the site\n\t\tendUser.access_Site();\n\t\t\n\t\t//Search Weather by CityName\n\t\tendUser.SearchWeatherbyCityName(city);\n\t\t\n\t\t//Assume that the test application is triggering the correct API as expectation: OncCall\n\t\tcity = endUser.getWeatherInfoViaAPIResponse(city);\n\t\t\n\t\t//Validate Current Weather\n\t\tendUser.Validate_CurrentWeather(city);\n\t\t\n\t\tAssert.assertTrue(TestConfigs.glb_TCFailedMessage, TestConfigs.glb_TCStatus);\n\t}", "@Override\n public boolean checkSensors() {\n HttpURLConnection conn;\n int tries = -1;\n int response = -1;\n URL url = null;\n try {\n do {\n tries++;\n url = new URL( mHost + \"/timeout/checkSensor\" ); // TODO wrong place for\n // appspecific prefix\n conn = (HttpURLConnection) url.openConnection();\n conn.setReadTimeout( 30000 /* milliseconds */);\n conn.setConnectTimeout( 30000 /* milliseconds */);\n conn.setRequestMethod( \"GET\" );\n conn.setDoInput( true );\n conn.setRequestProperty( \"Cookie\", \"X-SESSION_ID=\" + getXSession() );\n response = conn.getResponseCode();\n Log.d( TAG, \"The response is: \" + response );\n if ( response == 403 ) {\n relogin();\n } else if ( response == 200 ) {\n InputStreamReader reader = new InputStreamReader(\n conn.getInputStream() );\n CharBuffer buffer = CharBuffer.allocate( 256 );\n char[] cbuf = new char[ 256 ];\n StringBuffer body = new StringBuffer( 1024 );\n int read = -1;\n while ( (read = reader.read( buffer )) >= 0 ) {\n buffer.rewind();\n buffer.get( cbuf, 0, read );\n body.append( cbuf, 0, read );\n // body.append( buffer.subSequence( 0, read ) );\n buffer.clear();\n }\n if ( !body.toString().trim().toLowerCase().equals( \"ok\" ) ) {\n Log.e( TAG, \"Response from \" + url\n + \" was 200 but content was not ok\" );\n return false;\n }\n }\n } while ( response == 403 && tries < 3 );\n return true;\n } catch ( IOException e ) {\n Log.e( TAG, \"Something wicked happened while GETting to \" + url );\n e.printStackTrace();\n return false;\n }\n }", "public TemperatureResponse getTemperatures(TemperatureRequest request) throws Exception{\n TemperatureResponse r = this.db.getTemperatures(request.getNodeId(), request.getStartTime(), request.getEndTime(), MAX_RETURN_LIMIT);\n\n \n System.out.println(\"returning response.\");\n return r;\n }", "public void windChillFunction(int temperature,int speed) {\n\t\n\t\tif( ( temperature < 50) && ((speed < 120) || speed > 3 )) {\n\t\t\n\t\t\tfloat first = (float)(0.6215 * temperature);\n\t\t\tfloat second = (float)((0.4275*temperature) - 35.75);\n\t\t\tfloat thirdPower = (float)(Math.pow(speed, 0.16));\n\t\t\t\n\t\t\t// formula for calculation of the wind Chill....\n\t\t\t\n\t\t\tfloat Formula = (float)( ( 35.74 ) + first + (second * thirdPower ));\n\t\t\t\n\t\t\t// output of the WindChill Formula.....\n\t\t\tSystem.out.println(Formula);\n\t\t}else {\n\t\t\t\n\t\t\tSystem.out.println(\"entered temp. and speed is not valid\");\n\t\t\t\n\t\t\t// if condition false then print this.\n\t\t}\n\t\t\t\n\t}", "public boolean handleTempChange(int temp)\r\n\t{\r\n\t\tif (temp > 100) {\r\n\t\t\tSystem.out.print(\"Subsection \" + getName() + \" turning heater OFF due to hight temparture: \" + temp + \"\\n\");\r\n\t\t}\r\n\t\telse if (temp < 60) {\r\n\t\t\tSystem.out.print(\"Subsection \" + getName() + \" turning heater ON due to low temparture: \" + temp + \"\\n\");\r\n\t\t}\r\n\t\treturn true;\r\n\t}", "public void testRpcValues() {\n // Test Values\n Temperature currentTemperature = msg.getCurrentTemperature();\n Temperature temperatureHigh = msg.getTemperatureHigh();\n Temperature temperatureLow = msg.getTemperatureLow();\n Temperature apparentTemperature = msg.getApparentTemperature();\n Temperature apparentTemperatureHigh = msg.getApparentTemperatureHigh();\n String weatherSummary = msg.getWeatherSummary();\n DateTime time = msg.getTime();\n Float humidity = msg.getHumidity();\n Float cloudCover = msg.getCloudCover();\n Float moonPhase = msg.getMoonPhase();\n Integer windBearing = msg.getWindBearing();\n Float windGust = msg.getWindGust();\n Float windSpeed = msg.getWindSpeed();\n Integer nearestStormBearing = msg.getNearestStormBearing();\n Integer nearestStormDistance = msg.getNearestStormDistance();\n Float precipAccumulation = msg.getPrecipAccumulation();\n Float precipIntensity = msg.getPrecipIntensity();\n Float precipProbability = msg.getPrecipProbability();\n String precipType = msg.getPrecipType();\n Float visibility = msg.getVisibility();\n Image weatherIcon = msg.getWeatherIcon();\n\n // Valid Tests\n assertEquals(TestValues.MATCH, currentTemperature, TestValues.GENERAL_TEMPERATURE);\n assertEquals(TestValues.MATCH, temperatureHigh, TestValues.GENERAL_TEMPERATURE);\n assertEquals(TestValues.MATCH, temperatureLow, TestValues.GENERAL_TEMPERATURE);\n assertEquals(TestValues.MATCH, apparentTemperature, TestValues.GENERAL_TEMPERATURE);\n assertEquals(TestValues.MATCH, apparentTemperatureHigh, TestValues.GENERAL_TEMPERATURE);\n assertEquals(TestValues.MATCH, weatherSummary, TestValues.GENERAL_STRING);\n assertEquals(TestValues.MATCH, time, TestValues.GENERAL_DATETIME);\n assertEquals(TestValues.MATCH, humidity, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, cloudCover, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, moonPhase, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, windBearing, TestValues.GENERAL_INTEGER);\n assertEquals(TestValues.MATCH, windGust, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, windSpeed, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, nearestStormBearing, TestValues.GENERAL_INTEGER);\n assertEquals(TestValues.MATCH, nearestStormDistance, TestValues.GENERAL_INTEGER);\n assertEquals(TestValues.MATCH, precipAccumulation, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, precipIntensity, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, precipProbability, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, precipType, TestValues.GENERAL_STRING);\n assertEquals(TestValues.MATCH, visibility, TestValues.GENERAL_FLOAT);\n assertEquals(TestValues.MATCH, weatherIcon, TestValues.GENERAL_IMAGE);\n\n // Invalid/Null Tests\n WeatherData msg = new WeatherData();\n assertNotNull(TestValues.NOT_NULL, msg);\n\n assertNull(TestValues.NULL, msg.getCurrentTemperature());\n assertNull(TestValues.NULL, msg.getTemperatureHigh());\n assertNull(TestValues.NULL, msg.getTemperatureLow());\n assertNull(TestValues.NULL, msg.getApparentTemperature());\n assertNull(TestValues.NULL, msg.getApparentTemperatureHigh());\n assertNull(TestValues.NULL, msg.getApparentTemperatureLow());\n assertNull(TestValues.NULL, msg.getWeatherSummary());\n assertNull(TestValues.NULL, msg.getTime());\n assertNull(TestValues.NULL, msg.getHumidity());\n assertNull(TestValues.NULL, msg.getCloudCover());\n assertNull(TestValues.NULL, msg.getMoonPhase());\n assertNull(TestValues.NULL, msg.getWindBearing());\n assertNull(TestValues.NULL, msg.getWindGust());\n assertNull(TestValues.NULL, msg.getWindSpeed());\n assertNull(TestValues.NULL, msg.getNearestStormBearing());\n assertNull(TestValues.NULL, msg.getNearestStormDistance());\n assertNull(TestValues.NULL, msg.getPrecipAccumulation());\n assertNull(TestValues.NULL, msg.getPrecipIntensity());\n assertNull(TestValues.NULL, msg.getPrecipProbability());\n assertNull(TestValues.NULL, msg.getPrecipType());\n assertNull(TestValues.NULL, msg.getVisibility());\n assertNull(TestValues.NULL, msg.getWeatherIcon());\n }", "public double convertirTemperaturas(){\r\n double resultado=.0;\r\n if(unidadOrigen=='C' && unidadDestino == 'F'){\r\n resultado=Math.round(conversorTemperatura.obtenerDeCelsiusAFahrenheit());\r\n }else if(unidadOrigen=='C' && unidadDestino == 'K'){\r\n resultado=conversorTemperatura.obtenerDeCelsiusAKelvin();\r\n }else if(unidadOrigen=='F' && unidadDestino == 'C'){\r\n resultado=Math.round(conversorTemperatura.obtenerDeFahrenheitACelsius());\r\n }else if(unidadOrigen=='F' && unidadDestino == 'K'){\r\n resultado=conversorTemperatura.obtenerDeFahrenheitAKelvin();\r\n }else if (unidadOrigen=='K' && unidadDestino == 'C'){\r\n resultado=conversorTemperatura.obtenerDeKelvinACelsius();\r\n }else if (unidadOrigen=='K' && unidadDestino == 'F'){\r\n resultado=conversorTemperatura.obtenerDeKelvinAFahrenheit();\r\n }else if (unidadOrigen=='C' && unidadDestino == 'C'){\r\n resultado=conversorTemperatura.getNumero();\r\n }\r\n return resultado;\r\n }", "protected void onGetTemperatureSetting2(EchoObject eoj, short tid, byte esv, EchoProperty property, boolean success) {}", "@Override\r\n public void onChanged(BleDevice device, BluetoothGattCharacteristic characteristic) {\r\n L.e(TAG, \"onChanged==data:\" + Arrays.toString(characteristic.getValue()));\r\n\r\n /**\r\n * {\"tmp\":\"test\",\"now_tmp\":\"37.6\",\"max_tmp\":\"38.1\",\"min_tmp\":\"36.5\"} 模拟数据\r\n * */\r\n\r\n try {\r\n if (result == null) {\r\n result = sb.append(new String(characteristic.getValue(), \"UTF-8\"));\r\n String over = result.toString();\r\n Toast.makeText(getApplicationContext(),over,Toast.LENGTH_SHORT).show();\r\n } else {\r\n result = sb.append(new String(characteristic.getValue(), \"UTF-8\"));\r\n String over = result.toString();\r\n Toast.makeText(getApplicationContext(),over,Toast.LENGTH_SHORT).show();\r\n if (over.contains(\"}\")) {\r\n //解析\r\n JSONObject obj = new JSONObject(over);\r\n // String test = obj.getString(\"tmp\"); //test\r\n String current = obj.getString(\"now_tmp\"); //当前体温\r\n String max = obj.getString(\"max_tmp\"); //最高体温\r\n String min = obj.getString(\"min_tmp\");\r\n if (!TextUtils.isEmpty(current)) {\r\n tv_current_temperature.setText(current);\r\n } else {\r\n tv_current_temperature.setText(\"未知\");\r\n }\r\n if (!TextUtils.isEmpty(max)) {\r\n tv_max_temperature.setText(max);\r\n } else {\r\n tv_max_temperature.setText(\"未知\");\r\n }\r\n\r\n if (!TextUtils.isEmpty(min)) {\r\n tv_min_temperature.setText(min);\r\n } else {\r\n tv_min_temperature.setText(\"未知\");\r\n }\r\n\r\n }\r\n\r\n\r\n }\r\n\r\n } catch (Exception e) {\r\n Toast.makeText(getApplicationContext(),\"数据源格式出错\",Toast.LENGTH_SHORT).show();\r\n e.printStackTrace();\r\n }\r\n\r\n }", "@Test(dataProvider=\"WeatherTests\", dataProviderClass=DataProviders.class, enabled=true)\n\tpublic void WeatherTests(TestInput testInput) {\n\t\ttest = extent.startTest(\"Weather Test for \" + testInput.cityName);\n\t\ttest.log(LogStatus.INFO, \"Starting tests for \" + testInput.cityName);\n\n\t\ttry {\n\t\t\t//Checks if we were able to find an entry for the given city in the cities.json file\n\t\t\tif(testInput.city.id != null) {\n\t\t\t\tlog.debug(\"Found an entry for the city \" + testInput.cityName + \" in the Cities JSON File. Starting.\");\n\n\t\t\t\t//Extract the weather information from API for the given city\n\t\t\t\tCityWeatherInfo currenctCityWeatherInfoAPI = APIRequests.extractLatestWeatherForecastFromAPI(testInput, config.getProperty(\"APIKEY\"));\n\n\t\t\t\t//Extract the weather information from the website\n\t\t\t\tHomePage home = new HomePage();\n\t\t\t\thome.setTemperatureToFarenheit(); //Switch temperature to farenheit to be inline with the information from API\n\n\t\t\t\tSearchResultsPage resultsPage = home.searchCity(testInput.cityName.trim());\n\t\t\t\tCityWeatherPage cityWeatherPage = resultsPage.clickOnCityEntry(testInput.city.id.trim());\n\n\t\t\t\tArrayList<Double> forecastWeathers = cityWeatherPage.extractForecastTemperatures();\n\t\t\t\tcityWeatherPage.navigateToHourlyTab();\n\t\t\t\tCityWeatherInfo currenctCityAPIWeatherInfoWeb = cityWeatherPage.extractFirstForecastInfo();\n\n\t\t\t\t//////////// TEST 1 //////////////\n\t\t\t\t//Checks to see if the forecast weather information from API matches the data from website\n\t\t\t\tif(currenctCityWeatherInfoAPI.equals(currenctCityAPIWeatherInfoWeb))\n\t\t\t\t\ttest.log(LogStatus.PASS, \"TEST1: Weather information from API matches with website\");\n\t\t\t\telse {\n\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Weather information from API does not match with website\");\n\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.temperatureInFarenheit != currenctCityAPIWeatherInfoWeb.temperatureInFarenheit)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Temperature from API (\" + currenctCityWeatherInfoAPI.temperatureInFarenheit +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Temperature from Web (\" + currenctCityAPIWeatherInfoWeb.temperatureInFarenheit + \")\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.windSpeedInMPH != currenctCityAPIWeatherInfoWeb.windSpeedInMPH)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Wind Speed from API (\" + currenctCityWeatherInfoAPI.windSpeedInMPH +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Wind Speed from Web (\" + currenctCityAPIWeatherInfoWeb.windSpeedInMPH + \")\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.cloudCoverPercentage != currenctCityAPIWeatherInfoWeb.cloudCoverPercentage)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Cloud Coverage from API (\" + currenctCityWeatherInfoAPI.cloudCoverPercentage +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\"%) does not match Cloud Coverage from Web (\" + currenctCityAPIWeatherInfoWeb.cloudCoverPercentage + \"%)\");\n\t\n\t\t\t\t\tif(currenctCityWeatherInfoAPI.atmPressureInHPA != currenctCityAPIWeatherInfoWeb.atmPressureInHPA)\n\t\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST1: Atmospheric Pressure from API (\" + currenctCityWeatherInfoAPI.atmPressureInHPA +\n\t\t\t\t\t\t\t\t\t\t\t\t\t\") does not match Atmospheric Pressure from Web (\" + currenctCityAPIWeatherInfoWeb.atmPressureInHPA + \")\");\n\t\t\t\t}\n\n\t\t\t\t//////////// TEST 2 //////////////\n\t\t\t\t//Check whether the difference between minimum and maximum forecast temperature listed on website is less than 10 or not\n\t\t\t\tdouble minForecastWeather = Common.minValueInList(forecastWeathers), maxForecastWeather = Common.maxValueInList(forecastWeathers);\n\t\t\t\tdouble diffForecastWeather = maxForecastWeather - minForecastWeather; \n\t\t\t\tif(diffForecastWeather <= 10)\n\t\t\t\t\ttest.log(LogStatus.PASS, \"TEST2: Difference between Maximum Forecast Temperature (\" + maxForecastWeather + \") \"\n\t\t\t\t\t\t\t\t\t\t\t\t+ \"and Minimum Forecast Temperature (\" + minForecastWeather + \") is \" + diffForecastWeather\n\t\t\t\t\t\t\t\t\t\t\t\t+ \" which is less than 10 degrees farenheit\");\n\t\t\t\telse\n\t\t\t\t\ttest.log(LogStatus.FAIL, \"TEST2: Difference between Maximum Forecast Temperature (\" + maxForecastWeather + \") \"\n\t\t\t\t\t\t\t\t\t\t\t\t+ \"and Minimum forecast temperature (\" + minForecastWeather + \") is \" + diffForecastWeather\n\t\t\t\t\t\t\t\t\t\t\t\t+ \" which is greater than 10 degrees farenheit\");\n\t\t\t} else {\n\t\t\t\tlog.debug(\"Could not find an entry for the city \" + testInput.cityName + \" in the Cities JSON File. Skipping.\");\n\t\t\t\ttest.log(LogStatus.FAIL, \"Unable to find entry in cities.json for the city: \" + testInput.cityName);\n\t\t\t}\n\t\t} catch (Exception e) {\n\t\t\te.printStackTrace();\n\t\t} finally {\n\t\t\textent.endTest(test);\n\t\t}\n\t}", "public static int GetWarning(final double relativeHumidity, final double temperature)\n\t{\n\t\tdouble afw;\n\t\tdouble afa;\n\t\tdouble afs;\n\t\tdouble afc;\n\n\t\tif (temperature < 10.0)\n\t\t{ afs = (3.78 + (0.285 * temperature) + (0.0052 * temperature * temperature) + (0.0005 * temperature * temperature * temperature));\n\t\t}\n\t\telse\n\t\t{ afs = (7.62 + (0.524 * (temperature-10.0)) + (0.0131 * (temperature-10.0) * (temperature-10.0)) + (0.00048 * (temperature-10.0) * (temperature-10.0) * (temperature-10.0)));\n\t\t}\n\n\t\tafc = (afs * relativeHumidity) / (100.0 + afs * (100.0 - relativeHumidity) / 622);\n\n\t\tfinal double relativeHumidity2 = 65;\n\t\tafw = (afs * relativeHumidity2) / (100.0 + afs * (100.0 - relativeHumidity2) / 622);\n\n\t\tfinal double relativeHumidity3 = 75;\n\t\tafa = (afs * relativeHumidity3) / (100.0 + afs * (100.0 - relativeHumidity3) / 622);\n\n// System.out.println(\"AFC = \" + afc + \" AFW = \" + afw + \" AFA = \" + afa);\n\n\t\tif(afc < afw)\n\t\t{\n\t\t\treturn 0;\n\t\t}\n\t\telse if(afc < afa)\n\t\t{\n\t\t\treturn 1;\n\t\t}\n\t\telse\n\t\t{\n\t\t\treturn 2;\n\t\t}\n\t}", "@Test\n public void shouldReturnCornerCaseMinimumAmbientAirTemperature() {\n\n Integer testInput = 1;\n Integer expectedValue = -39;\n \n AmbientAirTemperature testAmbientAirTemperature = new AmbientAirTemperature(testInput);\n AmbientAirPressure testAmbientAirPressure = new AmbientAirPressure(0);\n \n WeatherProbe testWeatherProbe = new WeatherProbe(\n testAmbientAirTemperature,\n testAmbientAirPressure,\n mockWiperSet);\n \n Integer actualValue = OssWeatherProbe.genericWeatherProbe(testWeatherProbe).getAirTemp();\n \n assertEquals(expectedValue, actualValue);\n \n }", "private double calculateTemp(){\n if (!((Double)mplTemp).isNaN() && !((Double)shtTemp).isNaN()){\n return (mplTemp + shtTemp)/2;\n }\n\n return Double.NaN;\n }", "protected void onGetMeasuredFloorTemperature(EchoObject eoj, short tid, byte esv, EchoProperty property, boolean success) {}", "public Float getTemperature () {\n return temperature;\n }", "@Override\n public void requestWeatherSuccess(Weather weather, Location requestLocation) {\n try {\n if (request != null) {\n List<WeatherInfo.DayForecast> forecastList = new ArrayList<>();\n for (int i = 0; i < weather.dailyList.size(); i++) {\n forecastList.add(\n new WeatherInfo.DayForecast.Builder(\n WeatherConditionConvertHelper.getConditionCode(\n weather.dailyList.get(i).weatherKinds[0],\n true))\n .setHigh(weather.dailyList.get(i).temps[0])\n .setLow(weather.dailyList.get(i).temps[1])\n .build());\n }\n WeatherInfo.Builder builder = new WeatherInfo.Builder(\n weather.base.city,\n weather.realTime.temp,\n WeatherContract.WeatherColumns.TempUnit.CELSIUS)\n .setWeatherCondition(\n WeatherConditionConvertHelper.getConditionCode(\n weather.realTime.weatherKind,\n TimeManager.getInstance(this)\n .getDayTime(this, weather, false)\n .isDayTime()))\n .setTodaysHigh(weather.dailyList.get(0).temps[0])\n .setTodaysLow(weather.dailyList.get(0).temps[1])\n .setTimestamp(weather.base.timeStamp)\n .setHumidity(\n Double.parseDouble(\n weather.index.humidities[1]\n .split(\" : \")[1]\n .split(\"%\")[0]))\n .setWind(\n Double.parseDouble(weather.realTime.windSpeed.split(\"km/h\")[0]),\n weather.realTime.windDegree,\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH)\n .setForecast(forecastList);\n\n request.complete(new ServiceRequestResult.Builder(builder.build()).build());\n }\n } catch (Exception ignore) {\n requestWeatherFailed(requestLocation);\n }\n }", "public double getHumidityTemperature() {\r\n return humidityTemperature;\r\n }", "public boolean isValidTemperature() {\n\t\treturn false;\n\t}", "int surfaceTemperature(C config);", "int askForTempMin();", "public void submitRequest(String location, WebViewModel vmodel) {\n String weatherUrl = \"https://weather.visualcrossing.com/VisualCrossingWebServices/rest/services/timeline/\" + location + \"?key=QZ2CJDXT7CYASXM6598KXSPDX\";\n //URL below is free API testing\n //String weatherUrl = \"https://weather.visualcrossing.com/VisualCrossingWebServices/rest/services/timeline/%22%20+%20location%20+%20%22?key=QZ2CJDXT7CYASXM6598KXSPDX\";\n\n JsonObjectRequest jsonObjectRequest = new JsonObjectRequest\n (Request.Method.GET, weatherUrl, null, new Response.Listener<JSONObject>() {\n\n @RequiresApi(api = Build.VERSION_CODES.N)\n @Override\n public void onResponse(JSONObject response) {\n String cityName = \"\";\n String countryName = \"\";\n String time = \"\";\n String temperature = \"\";\n String maxTemp = \"\";\n String minTemp = \"\";\n String skyCondition = \"\";\n String humidity = \"\";\n String tomorrow = \"\";\n String tonight = \"\";\n JSONArray daysArray;\n SimpleDateFormat dateProperFormat;\n\n try {\n location_splicer(response.getString(\"resolvedAddress\"));\n } catch(JSONException e) {\n System.out.println(\"Error gathering location\");\n }\n try {\n cityName = cityName + cityName_holder;\n } catch (Exception e) {\n System.out.println(\"Error gathering cityName\");\n }\n try {\n countryName = countryName + countryName_holder;\n } catch (Exception e) {\n System.out.println(\"Error gathering countryName\");\n }\n\n //Let's get weather objects for each day.\n try {\n daysArray = response.getJSONArray(\"days\");\n } catch (JSONException e) {\n e.printStackTrace();\n daysArray = null;\n System.out.println(\"ERROR DAYSARRAY\");\n }\n\n try {\n Date currentTime = Calendar.getInstance().getTime();\n Locale locale = Locale.getDefault();\n dateProperFormat =\n new SimpleDateFormat (\"yyyy-MM-dd\", locale);\n\n time = daysArray.getJSONObject(0).getString(\"datetime\");\n\n }catch (JSONException e) {\n System.out.println(\"Error gathering time\");\n }\n\n try {\n temperature = daysArray.getJSONObject(0).getString(\"temp\");\n //temperature = response.getJSONObject(\"currentConditions\").getString(\"temp\");\n if (temperature.length() > 2) {\n temperature = temperature.substring(0,2);\n }\n //temperature = response.getJSONArray(\"days\").getJSONObject(0).getString(\"temp\");\n }catch (JSONException e) {\n System.out.println(\"Error gathering temperature\");\n }\n try {\n maxTemp = daysArray.getJSONObject(0).getString(\"tempmax\");\n } catch (JSONException e) {\n System.out.println(\"Error getting max temperature\");\n }\n try {\n minTemp = daysArray.getJSONObject(0).getString(\"tempmin\");\n } catch (JSONException e) {\n System.out.println(\"Error getting max temperature\");\n }\n try {\n skyCondition = daysArray.getJSONObject(0).getString(\"icon\");\n\n //response.getJSONObject(\"currentConditions\").getString(\"conditions\");\n } catch (JSONException e) {\n System.out.println(\"Error gathering conditions\");\n }\n try {\n humidity = daysArray.getJSONObject(0).getString(\"humidity\");\n } catch (JSONException e) {\n System.out.println(\"Error gathering humidity\");\n }\n try {\n JSONArray hours = daysArray.getJSONObject(0).getJSONArray(\"hours\");\n tonight = \"unknown\";\n for (int i = 0; i < hours.length(); i++) {\n if (hours.getJSONObject(i).getString(\"datetime\").equals(\"23:00:00\")) {\n tonight = hours.getJSONObject(i).getString(\"temp\");\n }\n }\n\n } catch (JSONException e) {\n e.printStackTrace();\n }\n try {\n tomorrow = daysArray.getJSONObject(1).getString(\"tempmax\");\n } catch (JSONException e) {\n e.printStackTrace();\n }\n\n\n WeatherReport newReport = new WeatherReport(cityName, countryName);\n\n newReport.updateWeatherReport(time, temperature, condition_parcer(skyCondition), humidity, maxTemp, minTemp, tomorrow, tonight);\n System.out.println(\"***JSON DATA***\");\n System.out.println(time);\n System.out.println(cityName);\n System.out.println(countryName);\n System.out.println(temperature);\n System.out.println(skyCondition);\n System.out.println(newReport.getHumidity());\n vmodel.addWeatherReport(newReport, context);\n System.out.println(\"Checking vmodel: \" +\n vmodel.getRecentReport().getLocationName_city() +\n \" is set as current city\");\n\n }\n }, error -> System.out.println(\"ERROR GETTING WEATHER\"));\n\n\n // Access the RequestQueue through your singleton class.\n this.addToRequestQueue(jsonObjectRequest);\n\n }", "public static boolean isPassOneHour(String pass)\n {\n DateFormat dateFormat = new SimpleDateFormat(\"yyyy-MM-dd HH:mm:ss\");\n Date date = new Date();\n String current = dateFormat.format(date);\n\n //Extract current data time all values\n\n int current_year = Integer.parseInt(current.substring(0, 4));\n int current_month = Integer.parseInt(current.substring(5,7))-1;\n int current_day = Integer.parseInt(current.substring(8,10));\n\n int current_hour = Integer.parseInt(current.substring(11,13));\n int current_minute = Integer.parseInt(current.substring(14,16));\n int current_seconds = Integer.parseInt(current.substring(17));\n\n //String pass = \"2016-10-05 10:14:00\";\n\n //Extract last update data (pass from parameter\n\n int year = Integer.parseInt(pass.substring(0, 4));\n int month = Integer.parseInt(pass.substring(5,7))-1;\n int day = Integer.parseInt(pass.substring(8,10));\n\n int hour = Integer.parseInt(pass.substring(11,13));\n int minute = Integer.parseInt(pass.substring(14,16));\n int seconds = Integer.parseInt(pass.substring(17));\n\n\n System.out.println(\"CURRENT: \" + current_year+\"/\"+current_month+\"/\"+current_day+\" \"+current_hour+\":\"+current_minute+\":\"+current_seconds);\n\n System.out.println(\"PASS: \" + year+\"/\"+month+\"/\"+day+\" \"+hour+\":\"+minute+\":\"+seconds);\n\n if (current_year == year)\n {\n if (current_month == month)\n {\n if (current_day == day)\n {\n if (current_hour > hour)\n {\n if ((current_hour - hour > 1))\n {\n //Bi ordu gutxienez\n System.out.println(\"Bi ordu gutxienez: \" + (current_hour) + \" / \" + hour);\n return true;\n }\n else\n {\n if (((current_minute + 60) - minute ) < 60)\n {\n //Ordu barruan dago\n System.out.println(\"Ordu barruan nago ez delako 60 minutu pasa: \" + ((current_minute + 60) - minute ));\n return false;\n }\n else\n {\n //Refresh\n System.out.println(\"Eguneratu, ordu bat pasa da gutxienez: \" + ((current_minute + 60) - minute ));\n return true;\n }\n }\n\n }\n }\n }\n }\n return false;\n }", "public double getExternalTemperature() {\r\n return externalTemperature;\r\n }", "public String getCpuTemperature_huawei(){\n\n String maxTemp = \"\";\n try {\n RandomAccessFile reader = new RandomAccessFile( \"/sys/class/thermal/thermal_zone1/temp\", \"r\" );\n\n boolean done = false;\n while ( ! done ) {\n String line = reader.readLine();\n if ( null == line ) {\n done = true;\n break;\n }\n maxTemp =line;\n }\n\n } catch ( IOException ex ) {\n ex.printStackTrace();\n }\n return String.valueOf(Double.parseDouble(maxTemp) / 1000);\n }", "public int getTemperature() {\n return temperature;\n }", "@Test\n public void shouldReturnUnknownAmbientAirTemperature() {\n \n Integer testInput = 191;\n Integer expectedValue = null;\n \n AmbientAirTemperature testAmbientAirTemperature = new AmbientAirTemperature(testInput);\n AmbientAirPressure testAmbientAirPressure = new AmbientAirPressure(0);\n \n WeatherProbe testWeatherProbe = new WeatherProbe(\n testAmbientAirTemperature,\n testAmbientAirPressure,\n mockWiperSet);\n \n Integer actualValue = OssWeatherProbe.genericWeatherProbe(testWeatherProbe).getAirTemp();\n \n assertEquals(expectedValue, actualValue);\n \n }", "public void checkWeather(Weather updatedWeather) {\r\n weather.setWeather(updatedWeather);\r\n }", "public int getTemperature() {\n return temperature;\n }", "private void AskForTempData()\n {\n //Creates connection\n String[] connectionData = new String[2];\n connectionData[0] = getResources().getString(R.string.server_get_temp_status);\n connectionData[1] = \"?DeviceCode=\"+deviceCode;\n new GetTempStatus(this).execute(connectionData);\n }", "private boolean isFireOut(double lat,double lon) {\n\t\tboolean result = false;\n\n\t\tString urlFires = \"http://localhost:8083/fires/intensity?lat=\"+lat+\"&lon=\"+lon;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\tResponseEntity<Float> response = restTemplate.exchange(urlFires, HttpMethod.GET,null,Float.class);\n\t\tFloat intensity = response.getBody();\n\t\t\n\t\tif(Math.abs(intensity)<1e-1) {\n\t\t\tresult = true;\n\t\t}\n\t\t\nSystem.out.println(\"Fire at \"+lat+\":\"+lon +\" intensity: \"+intensity);\n\t\treturn result;\n\t\t\n\t}", "@SuppressLint(\"SetTextI18n\")\n @Override\n protected void onGetDataSuccess() {\n TextView temperatureTextView = root.findViewById(R.id.temperature_now);\n temperatureTextView.setText(telemetryModel.Temperature.toString() + \"°C\");\n\n TextView pressureValueTextView = root.findViewById(R.id.pressure_value_now);\n pressureValueTextView.setText(telemetryModel.Pressure.toString() + \" mm Hg\");\n\n TextView moistureValueTextView = root.findViewById(R.id.moisture_value_now);\n moistureValueTextView.setText(telemetryModel.Moisture.toString() + \" %\");\n\n TextView luminosityValueTextView = root.findViewById(R.id.luminosity_value_now);\n luminosityValueTextView.setText(telemetryModel.Luminosity.toString() + \" lx\");\n }", "@Test\n public void shouldReturnMaximumAmbientAirTemperature() {\n\n Integer testInput = 190;\n Integer expectedValue = 150;\n \n AmbientAirTemperature testAmbientAirTemperature = new AmbientAirTemperature(testInput);\n AmbientAirPressure testAmbientAirPressure = new AmbientAirPressure(0);\n \n WeatherProbe testWeatherProbe = new WeatherProbe(\n testAmbientAirTemperature,\n testAmbientAirPressure,\n mockWiperSet);\n \n Integer actualValue = OssWeatherProbe.genericWeatherProbe(testWeatherProbe).getAirTemp();\n \n assertEquals(expectedValue, actualValue);\n \n }", "protected void onGetTemperatureSetting1(EchoObject eoj, short tid, byte esv, EchoProperty property, boolean success) {}", "@Test\n public void addInvalidLatLonTemp() throws Exception {\n double lat = 91;\n double lon = 181;\n double temperature = -273.16;\n\n performPostAdd(new Temperature(temperature, lat, lon))\n .andExpect(status().isBadRequest())\n .andExpect(content().string(INVALID_LATITUDE_MATCHER))\n .andExpect(content().string(INVALID_LONGITUDE_MATCHER))\n .andExpect(content().string(INVALID_TEMPERATURE_MATCHER));\n }", "@Override\n public void run() {\n for(int i=0;i<TheWeatherMan.WEATHER_CHECKS; i++) {\n\n // Have some delay\n try {\n Thread.sleep(1000* startTime);\n } catch (InterruptedException e) {\n System.out.println(\"『 Weather Report 』 Pacific has gone berserk and cant sleep.\\n\" +\n \"Terminating Program...\");\n System.exit(1);\n }\n\n /**\n * Handling Different City Temperatures -------------------------------------------\n */\n\n\n // Handling Singapore Temperatures\n if(cityName == \"Singapore\") {\n\n // Generates a random number between -.3 and .3\n double randNum = (Math.random() * (.6)) - .3;\n // Formats decimals to 2 places\n DecimalFormat df = new DecimalFormat(\"#.##\");\n\n cityTemperature = Double.valueOf(df.format((cityTemperature + randNum)));\n // Set Temp\n ((Satellite) satellite).setWeather1(cityTemperature);\n }\n\n // Handling Melbourne Temperatures\n if(cityName == \"Melbourne\") {\n Random random = new Random();\n double temp = (double) random.nextInt(45) + random.nextDouble();\n\n cityTemperature = temp;\n // Set Temp\n ((Satellite) satellite).setWeather2(cityTemperature);\n }\n\n // Handling Shanghai Temperatures\n if(cityName == \"Shanghai\") {\n\n // Fluctuate +-5\n Random random = new Random();\n double temp = ((double) random.nextInt(5) +\n random.nextDouble()) * (random.nextBoolean() ? 1 : -1);\n\n\n cityTemperature = cityTemperature + temp;\n // Set Temp\n ((Satellite) satellite).setWeather3(cityTemperature);\n }\n\n }\n }", "public void perferredTemperature(double mintemp, double maxtemp) {\n\t\tSystem.out.println(\"Preferredtemperature method\");\n\t\tminTemperature = mintemp;\n\t\tmaxTemperature = maxtemp;\n\t\t\n\t}", "private int syncEnergyData() throws IOException {\n\n // initialize some useful dates\n Calendar today = Calendar.getInstance();\n //today.add(Calendar.MINUTE, -15);\n Calendar year_ago = Calendar.getInstance();\n year_ago.add(Calendar.YEAR, -1);\n Calendar week_ago = Calendar.getInstance();\n week_ago.add(Calendar.MONTH, -1);\n Calendar day_ago = Calendar.getInstance();\n day_ago.add(Calendar.DATE, -1);\n\n\n String consumption_point = \"carleton_campus_en_use\";\n String production_point = \"carleton_wind_production\";\n\n //get the two live data points for first screen\n\n String quarter_hourly_consumption = readEnergyJSON(day_ago.getTime(), today.getTime(), \"quarterhour\", consumption_point);\n Log.i(\"quarter_hourly_consumption\", quarter_hourly_consumption);\n // update liveConsumption based on data from most recent complete 1/4 hour\n String[] consumption_list = quarter_hourly_consumption.split(\"[\\n|\\r]\");\n String recent_consumption_line = consumption_list[consumption_list.length - 2];\n liveConsumption = (Double.parseDouble(recent_consumption_line.substring(recent_consumption_line.indexOf(';') + 1, recent_consumption_line.length())));\n\n // quarter-hourly windmill1 production for past 24 hours\n String quarter_hourly_production1 = readEnergyJSON(day_ago.getTime(), today.getTime(), \"quarterhour\", production_point);\n // update liveProduction based on data from most recent complete 1/4 hour\n String[] production1_list = quarter_hourly_production1.split(\"[\\n|\\r]\");\n String recent_production1_line = production1_list[production1_list.length - 2];\n liveProduction1 = (Double.parseDouble(recent_production1_line.substring(recent_production1_line.indexOf(';') + 1, recent_production1_line.length())));\n\n // update values stored in sharedPref for next time app loads\n SharedPreferences sharedPref = context.getSharedPreferences(PREFS_NAME, Context.MODE_PRIVATE);\n SharedPreferences.Editor ed = sharedPref.edit();\n ed.putFloat(\"liveConsumption\", (float)liveConsumption);\n ed.putFloat(\"liveProduction1\", (float)liveProduction1);\n ed.commit();\n\n\n // get all the graph data and save in files\n String[] time_units = {\"day\", \"hour\", \"quarterhour\"};\n Date[] start_dates = {year_ago.getTime(), week_ago.getTime(), day_ago.getTime()};\n String[] points = {consumption_point, production_point};\n String[] dependent_variables = {\"consumption\", \"production1\"};\n\n for (int i = 0; i < time_units.length; i++) {\n String increment = time_units[i];\n Date start = start_dates[i];\n\n for (int j = 0; j < points.length; j++) {\n String data = readEnergyJSON(start, today.getTime(), increment, points[j]);\n\n try {\n DataOutputStream out = new DataOutputStream(\n context.openFileOutput(increment + \"_\" + dependent_variables[j] +\n \"_data\", Context.MODE_PRIVATE));\n out.writeUTF(data);\n out.close();\n } catch (IOException e) {\n Log.i(\"syncEnergyData\", \"I/O Error\");\n }\n }\n }\n return 0;\n }", "public int getTempOfStock() {\n // store the biggest min temp. and smallest max temp.\n int smallestMaxTemp = 0, biggestMinTemp = Integer.MAX_VALUE;\n // for each item in stock\n for (int i = 0; i < this._noOfItems; i++) {\n FoodItem currentItem = this._stock[i];\n // if first, don't compare at all.\n if (i == 0) {\n smallestMaxTemp = currentItem.getMaxTemperature();\n biggestMinTemp = currentItem.getMinTemperature();\n }\n else {\n // check and set the smallest max and biggest min:\n smallestMaxTemp = Math.min(currentItem.getMaxTemperature(), smallestMaxTemp);\n biggestMinTemp = Math.max(currentItem.getMinTemperature(), biggestMinTemp);\n // check if there's no value between both values:\n if ((smallestMaxTemp - biggestMinTemp) < 0)\n // so the values are invalid, there's no range between so we'll return Integer.MAX_VALUE authout continuing.\n return Integer.MAX_VALUE;\n }\n }\n return biggestMinTemp;\n }", "public MarsWeather(JSONObject info) throws Exception {\n\n\t\tDecimalFormat temp = new DecimalFormat(\"#.#\");\n\t\t \n\t\t //Declare Json Objects for use\n\t\t JSONObject data = info.getJSONObject(\"report\");\n\t\t \n\t\t //TEMPERATURE\n\t\t int maxTemp = data.getInt(\"max_temp\");\n\t\t int minTemp = data.getInt(\"min_temp\");\n\t\t int avgTemp = (maxTemp+minTemp)/2;\n\t\t \n\t\t //TEMPERATURE\n\t\t int maxFTemp = data.getInt(\"max_temp_fahrenheit\");\n\t\t int minFTemp = data.getInt(\"min_temp_fahrenheit\");\n\t\t int avgFTemp = (maxFTemp+minFTemp)/2;\n\t\t \n\t\t //DATE\n\t\t String date = data.getString(\"terrestrial_date\"); //Earth Date\n\t\t String season = data.getString(\"season\"); //Martian Month\n\t\t String totalDate = date + \" (\" + season + \" on mars)\";\n\t\t \n\t\t //WIND\n\t\t String windDirection = data.getString(\"wind_direction\");\n\t\t Object windSpeed = data.get(\"wind_speed\");\n\t\t \n\t\t //PRESSURE\n\t\t int pressureNum = data.getInt(\"pressure\");\n\t\t String pressureString = data.getString(\"pressure_string\");\n\t\t //String pressure = temp.format(pressureNum) + \" (\" + pressureString + \")\";\n\t\t String pressure = temp.format(pressureNum);\n\t\t \n\t\t //HUMIDITY + CONDITION\n\t\t Object humidity = data.get(\"abs_humidity\"); \n\t\t String skyCondition = data.getString(\"atmo_opacity\");\n\t\t String atmoOpacity = data.getString(\"atmo_opacity\");\n\t\t \n\t\t\n\t\tthis.date = String.format(\"Date of update: \" + totalDate);\n\t\tthis.temperature = temp.format(avgTemp) + \"\\u00b0\";\n\t\tthis.Ftemp = temp.format(avgFTemp) + \"\\u00b0\";\n\t\t\n\t\tif (!windDirection.equals(\"--\"))\n\t\t\tthis.windDirection = (\"Wind Direction: \" + windDirection);\n\t\t else this.windDirection = (\"\");\n\t\t \n\t\t if (!windSpeed.equals(null))\n\t\t\t this.windDirection = (\"Wind speed \" + windSpeed);\n\t\t else this.windSpeed = (\"No wind speed available.\");\n\t\t \n\t\t if (!humidity.equals(null))\n\t\t\t this.humidity = (\"Humidity \"+ humidity);\t\n\t\t else this.humidity = (\"No humidity available.\");\t \n\t\tthis.atmoOpacity = atmoOpacity;\n\t\tthis.skyCondition = \"Sky Conditon: \" + skyCondition;\n\t\tthis.pressure = pressure + \" KpA\";\n\t\t\n\t}", "public static boolean validateVariance(String city) {\n try {\n List<Double> web = getWebTempValues(city);\n List<Double> api = getAPITempValues();\n List<Double> variance = IntStream.range(0, web.size()).mapToObj(i -> web.get(i) - api.get(i)).collect(Collectors.toList());\n boolean flag = false;\n for (Double d : variance) {\n if (d > 0 && d < 1) flag = true;\n else throw new TemperatureDifferenceException(\"Temperature difference not within specified range\");\n }\n return flag;\n } catch (TemperatureDifferenceException e) {\n e.printStackTrace();\n return false;\n }\n }", "@Cacheable(\"darkSkyTemperature\")\n public WeatherDataDto getTemperature(@NonNull String city, @NonNull String countryCode) {\n ResponseEntity<String> response = getWeather(city, countryCode);\n if (response.getStatusCode() == HttpStatus.OK) {\n JSONObject jsonObject = new JSONObject(response.getBody());\n String temperature = String.valueOf(jsonObject\n .getJSONObject(\"currently\")\n .getDouble(\"temperature\"));\n\n WeatherDataDto weatherDataDto = new WeatherDataDto();\n weatherDataDto.setServiceName(getServiceName());\n weatherDataDto.setName(city);\n weatherDataDto.setCountry(countryCode);\n weatherDataDto.setTemperature(temperature);\n\n return weatherDataDto;\n } else {\n return new WeatherDataDto(ServiceName.DARK_SKY, response.getBody());\n }\n }", "public String weatherDataFromApi(WeatherData weatherData) {\n //GETTING DATA FROM API;\n ResponseEntity<WeatherInfoResponse> responseEntity = restTemplate.getForEntity(\"http://api.openweathermap.org/data/2.5/weather?q=\" + weatherData.getCityName() + \"&appid=a8775018b559279894847e4fe88bcd30\" + \"&units=metric\", WeatherInfoResponse.class);\n if (true) {\n //FROM WEATHERINFORESPONSE YOU CAN MODIFY WHAT YOU WANT TO GET FROM JASON WHICH COMES FROM API RESPONSE;\n WeatherInfoResponse body = responseEntity.getBody();\n String temp = body.getMain().getTemp();\n String deg = body.getWind().getDeg();\n String speed = body.getWind().getSpeed();\n //NEW OBJECT\n Weather weather = new Weather();\n weather.setCityName(weatherData.getCityName());\n weather.setTemperature(temp);\n weather.setWindSpeed(speed);\n weather.setWindDeg(deg);\n weather.setDate(LocalDateTime.now());\n weatherRepo.save(weather);\n return \"Hello there! Temperature in \" + weatherData.getCityName() + \" is \" + temp + \"C and wind parameters are = \" + speed + \"m/s and \" + deg + \" degrees\" ;\n } else {\n throw new HttpClientErrorException(HttpStatus.NOT_FOUND);\n }\n }", "public void setTemperature(int temperature) {\n if (status) {\n this.temperature = temperature;\n } else System.out.println(\"dispozitivul este oprit\");\n }", "public static double getHumidity(String weatherInfos) {\n\t\tMap<String, Object> respMap = jsonToMap(weatherInfos.toString());\n\t\tMap<String, Object> mainMap = jsonToMap(respMap.get(\"main\").toString());\n\t\t\n\t\tObject humidityObject = mainMap.get(\"humidity\");\n\t\t\n\t\tdouble humidity = (double)humidityObject;\n\t\t\n\t\tdouble rounded = BigDecimal.valueOf(humidity)\n\t\t\t\t.setScale(2, RoundingMode.HALF_UP)\n\t\t\t\t.doubleValue();\n\t\treturn rounded;\n\n\t}", "@Override\r\n public String getInfo(){\r\n String info = \"Temperature\\n\" + temperature.toString();\r\n if (temperature.getValue() <= 36.0){\r\n info += \"\\nAttention! The temperature is off the healthy values, you can enter hypothermia state, please consider seeing a doctor.\";\r\n } else if (temperature.getValue() >= 37.4) {\r\n info += \"\\nAttention! The temperature is off the healthy values, you have a fever, please consider seeing a doctor.\";\r\n } else {\r\n info += \"\\nHealthy!\";\r\n }\r\n return info + \"\\n--------------------------------------------\\n\";\r\n }", "private void fetchdata(String countries)\n {\n final String url = \"https://api.weatherapi.com/v1/forecast.json?key=20cc9a9b0a4243b4be970612211704&q=\"+countries+\"&days=1&aqi=no&alerts=no\";\n\n StringRequest request = new StringRequest(Request.Method.GET, url, new Response.Listener<String>() {\n @Override\n public void onResponse(String response)\n {\n\n // Handle the JSON object and\n // handle it inside try and catch\n try {\n\n // Creating object of JSONObject\n JSONObject jsonObject = new JSONObject(response);\n country.setText(\"Region: \"+jsonObject.getJSONObject(\"location\").getString(\"region\"));\n currentWeather.setText(\"Currently \"+jsonObject.getJSONObject(\"current\").getJSONObject(\"condition\").getString(\"text\"));\n humidity.setText(\"Current Humidity: \"+jsonObject.getJSONObject(\"current\").getString(\"humidity\"));\n temperature.setText(\"Current°C: \"+jsonObject.getJSONObject(\"current\").getString(\"temp_c\"));\n temperatureF.setText(\"Current°F: \"+jsonObject.getJSONObject(\"current\").getString(\"temp_f\"));\n time.setText(\"Current Time: \"+jsonObject.getJSONObject(\"location\").getString(\"localtime\"));\n countryZone.setText(\"Current Zone: \"+jsonObject.getJSONObject(\"location\").getString(\"tz_id\"));\n windD.setText(\"Direction: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_dir\"));\n windS.setText(\"Speed: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_kph\")+\" Kph\");\n windDegree.setText(\"Degree: \"+jsonObject.getJSONObject(\"current\").getString(\"wind_degree\")+\" °\");\n\n JSONArray jsonArray = jsonObject.getJSONObject(\"forecast\").getJSONArray(\"forecastday\");\n for(int i = 0;i<jsonArray.length();i++){\n jsonObject = jsonArray.getJSONObject(i);\n tWeather = jsonObject.getJSONObject(\"day\").getJSONObject(\"condition\").getString(\"text\");\n tDate = jsonObject.getString(\"date\");\n tTempC = jsonObject.getJSONObject(\"day\").getString(\"avgtemp_c\");\n tTempF = jsonObject.getJSONObject(\"day\").getString(\"avgtemp_f\");\n tHumidity = jsonObject.getJSONObject(\"day\").getString(\"avghumidity\");\n\n phases = jsonObject.getJSONObject(\"astro\").getString(\"moon_phase\");\n sunriseT = jsonObject.getJSONObject(\"astro\").getString(\"sunrise\");\n sunsetT = jsonObject.getJSONObject(\"astro\").getString(\"sunset\");\n moonriseT = jsonObject.getJSONObject(\"astro\").getString(\"moonrise\");\n moonsetT = jsonObject.getJSONObject(\"astro\").getString(\"moonset\");\n TwillRain = jsonObject.getJSONObject(\"day\").getString(\"daily_chance_of_rain\");\n Twillsnow = jsonObject.getJSONObject(\"day\").getString(\"daily_chance_of_snow\");\n\n }\n forecastWeather.setText(tWeather+\" later\");\n tempTommorrowF.setText(\"Avg daily °F: \"+tTempF);\n tempTommorowC.setText(\"Avg daily °C: \"+tTempC);\n TchanceRain.setText(\"Chances of Rain \"+TwillRain+\" %\");\n TchanceSnow.setText(\"Chances of Snow \"+Twillsnow+\" %\");\n humidityT.setText(\"Humidity: \"+tHumidity);\n //myuri = Uri.parse(uriS);\n Tphases.setText(\"Moon Phases \"+phases);\n Tsunrise.setText(\"Sunsrise: \"+sunriseT);\n Tsunset.setText(\"Sunset: \"+sunsetT);\n Tmoonrise.setText(\"moonrise: \"+moonriseT);\n Tmoonset.setText(\"moonset: \"+moonsetT);\n\n\n }\n catch (JSONException e) {\n e.printStackTrace();\n }\n }\n },\n new Response.ErrorListener() {\n @Override\n public void onErrorResponse(VolleyError error)\n {\n Toast.makeText(\n MainActivity.this,\n error.getMessage(),\n Toast.LENGTH_SHORT)\n .show();\n }\n });\n\n RequestQueue requestQueue = Volley.newRequestQueue(this);\n requestQueue.add(request);\n requestQueue.getCache().clear();\n }", "@Test\n public void testGetSetTemperaturaExterior() {\n System.out.println(\"getSetTemperaturaExterior\");\n double expResult = 20.0;\n Simulacao simulacao = new Simulacao();\n simulacao.setSala(sala);\n AlterarTemperaturasMeioController instance = new AlterarTemperaturasMeioController(simulacao);\n instance.setTemperaturaExterior(expResult);\n double result = instance.getTemperaturaExterior();\n assertEquals(expResult, result, 0.0);\n }", "@Override\n protected WeatherInfo doInBackground(Void... params) {\n String weatherID = \"\";\n String areaID = \"\";\n try {\n String cityIds = null;\n if (mRequest.getRequestInfo().getRequestType()\n == RequestInfo.TYPE_WEATHER_BY_WEATHER_LOCATION_REQ) {\n cityIds = mRequest.getRequestInfo().getWeatherLocation().getCityId();\n weatherID = cityIds.split(\",\")[0];\n areaID = cityIds.split(\",\")[1];\n } else if (mRequest.getRequestInfo().getRequestType() ==\n RequestInfo.TYPE_WEATHER_BY_GEO_LOCATION_REQ) {\n double lat = mRequest.getRequestInfo().getLocation().getLatitude();\n double lng = mRequest.getRequestInfo().getLocation().getLongitude();\n\n String cityNameResponse = HttpRetriever.retrieve(String.format(GEO_URL, lat, lng));\n if (TextUtils.isEmpty(cityNameResponse)) {\n return null;\n }\n cityNameResponse = cityNameResponse.replace(\"renderReverse&&renderReverse(\", \"\").replace(\")\", \"\");\n Log.d(TAG, \"cityNameResponse\" + cityNameResponse);\n JSONObject jsonObjectCity = JSON.parseObject(cityNameResponse);\n String areaName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"district\");\n String cityName = jsonObjectCity.getJSONObject(\"result\").getJSONObject(\"addressComponent\").getString(\"city\");\n areaName = TextUtil.getFormatArea(areaName);\n cityName = TextUtil.getFormatArea(cityName);\n City city = cityDao.getCityByCityAndArea(cityName, areaName);\n if (city == null) {\n city = cityDao.getCityByCityAndArea(cityName, cityName);\n if (city == null)\n return null;\n }\n weatherID = city.getWeatherId();\n areaID = city.getAreaId();\n } else {\n return null;\n }\n\n //miui天气\n String miuiURL = String.format(URL_WEATHER_MIUI, weatherID);\n if (DEBUG) Log.d(TAG, \"miuiURL \" + miuiURL);\n String miuiResponse = HttpRetriever.retrieve(miuiURL);\n if (miuiResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"Rmiuiesponse \" + miuiResponse);\n\n //2345天气\n String ttffUrl = String.format(URL_WEATHER_2345, areaID);\n if (DEBUG) Log.d(TAG, \"ttffUrl \" + ttffUrl);\n String ttffResponse = DecodeUtil.decodeResponse(HttpRetriever.retrieve(ttffUrl));\n if (ttffResponse == null) return null;\n if (DEBUG) Log.d(TAG, \"ttffResponse \" + ttffResponse);\n\n\n JSONObject ttffAll = JSON.parseObject(ttffResponse);\n String cityName = ttffAll.getString(\"cityName\");\n //实时\n JSONObject sk = ttffAll.getJSONObject(\"sk\");\n String humidity = sk.getString(\"humidity\");\n String sk_temp = sk.getString(\"sk_temp\");\n\n //日落日升\n JSONObject sunrise = ttffAll.getJSONObject(\"sunrise\");\n\n ArrayList<WeatherInfo.DayForecast> forecasts =\n parse2345(ttffAll.getJSONArray(\"days7\"), true);\n\n WeatherInfo.Builder weatherInfo = null;\n weatherInfo = new WeatherInfo.Builder(\n cityName, sanitizeTemperature(Double.parseDouble(sk_temp), true),\n WeatherContract.WeatherColumns.TempUnit.CELSIUS);\n //湿度\n humidity = humidity.replace(\"%\", \"\");\n weatherInfo.setHumidity(Double.parseDouble(humidity));\n\n if (miuiResponse != null) {\n //风速,风向\n JSONObject weather = JSON.parseObject(miuiResponse);\n JSONObject accu_cc = weather.getJSONObject(\"accu_cc\");\n weatherInfo.setWind(accu_cc.getDouble(\"WindSpeed\"), accu_cc.getDouble(\"WindDirectionDegrees\"),\n WeatherContract.WeatherColumns.WindSpeedUnit.KPH);\n }\n\n weatherInfo.setTimestamp(System.currentTimeMillis());\n weatherInfo.setForecast(forecasts);\n\n if (forecasts.size() > 0) {\n weatherInfo.setTodaysLow(sanitizeTemperature(forecasts.get(0).getLow(), true));\n weatherInfo.setTodaysHigh(sanitizeTemperature(forecasts.get(0).getHigh(), true));\n weatherInfo.setWeatherCondition(IconUtil.getWeatherCodeByType(\n ttffAll.getJSONArray(\"days7\").getJSONObject(0).getString(\n DateTimeUtil.isNight(sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\"))\n ? \"nightWeaShort\" : \"dayWeaShort\"), sunrise.getString(\"todayRise\"), sunrise.getString(\"todaySet\")));\n }\n\n if (lastWeatherInfo != null)\n lastWeatherInfo = null;\n\n lastWeatherInfo = weatherInfo.build();\n\n return lastWeatherInfo;\n } catch (Exception e) {\n if (DEBUG) Log.w(TAG, \"JSONException while processing weather update\", e);\n }\n return null;\n }", "public String getTemperature(JSONObject j) throws JSONException{\n return roundTwoDecimals(Utilities.convertTemp(tempUnits,j.getDouble(\"day\"))) + \"\";\n }", "private int calculateTemp(){\n\n int time = (int) Bukkit.getServer().getWorld(worldName).getTime();\n\n // Calculate temp (y value) on a manipulated sine wave\n return (int) Math.round(\n Math.sin( (time * 0.000262) - ( (peakTime/24000.0) * Math.PI * 2 ) + (0.5 * Math.PI) ) * ((maxTemp-minTemp)/2.0)\n + (minTemp + ((maxTemp-minTemp)/2.0))\n );\n }", "public String getTemperature() {\n return temperature;\n }", "@Test\n\tpublic void dayTimeAndNightTimeAreDetectedCorrectlyTest() {\n\t\tcurrentDate = LocalDate.of(2019, 01, 27);\n\t\tAverageTemperatureAndPressure atp = forecastService.getAverageTemperatureAndPressure(city, currentDate, 3);\n\t\t\n\t\tassertEquals(3, atp.getAvrgDayTimeTemperature(), 0.000000001);\n\t\tassertEquals(7, atp.getAvrgNightTimeTemperature(), 0.000000001);\n\t\tassertEquals(6, atp.getAvrgPressure(), 0.000000001);\n\t}", "@Override\r\n public void runTests() {\r\n getTemperature();\r\n }", "@Test\n\tpublic void testEquals6(){\n\t\tTemperature data1 = new Temperature (100, Temperature.Units.KELVIN);\n\t\tTemperature data2 = new Temperature (100, Temperature.Units.CELCIUS);\n\t\tassertEquals(data1.equals(data2), false);\t//Since '100 kelvin' and '100 celcius' are different, equals() function should return false \n\t\tassertTrue(data1.getValue() == 100);\t\t//equals() function should not affect return value of getValue() function and should return the original value\n\t\tassertTrue(data2.getValue() == 100);\t\t//equals() function should not affect return value of getValue() function and should return the original value\t\n\t}", "private void updateTemperatureImage(float temperature) {\n \t\t\n \t\t//determine which drawable to use\n \t\tif(temperature < maxColdTemp) {\n \t\t\tif(coldTempDrawable == null) {\n \t\t\t\tcoldTempDrawable = getResources().getDrawable(R.drawable.temperature_cold);\n \t\t\t}\n \t\t\ttemperatureImgView.setImageDrawable(coldTempDrawable);\n \t\t} else if(temperature > minHotTemp) {\n \t\t\tif(hotTempDrawable == null) {\n \t\t\t\thotTempDrawable = getResources().getDrawable(R.drawable.temperature_hot);\n \t\t\t}\n \t\t\ttemperatureImgView.setImageDrawable(hotTempDrawable);\n \t\t} else {\n \t\t\tif(warmTempDrawable == null) {\n \t\t\t\twarmTempDrawable = getResources().getDrawable(R.drawable.temperature_warm);\n \t\t\t}\n \t\t\ttemperatureImgView.setImageDrawable(warmTempDrawable);\n \t\t}\n \t}", "public float getTemperature() {\n\t\treturn (float) getRawTemperature() / 100f;\n\t}", "@Test\n public void shouldReturnCornerCaseMaximumAmbientAirTemperature() {\n\n Integer testInput = 189;\n Integer expectedValue = 149;\n \n AmbientAirTemperature testAmbientAirTemperature = new AmbientAirTemperature(testInput);\n AmbientAirPressure testAmbientAirPressure = new AmbientAirPressure(0);\n \n WeatherProbe testWeatherProbe = new WeatherProbe(\n testAmbientAirTemperature,\n testAmbientAirPressure,\n mockWiperSet);\n \n Integer actualValue = OssWeatherProbe.genericWeatherProbe(testWeatherProbe).getAirTemp();\n \n assertEquals(expectedValue, actualValue);\n \n }", "public static void temperatureConversion()\n\t{\n\t\tSystem.out.println(\"enter temperature in farenheit\");\n\t\tdouble mTemperatureFarenheit = scanner.nextDouble();\n\t\t\t\n\t\tdouble mToCelcius = ((mTemperatureFarenheit - 32) / 1.8);\n\t\tdouble mToFarenheit = ((mToCelcius * 1.8) + 32);\n\t\tSystem.out.println(\"temperature in celcius is \" + mToCelcius);\n\t\tSystem.out.println(\"temperature in farenheit is \" +mToFarenheit);\n\t\t\n\t}", "public static int getTemperature() {\n\t\t\n\t\tSystem.out.println(\"Enter temperature value : \");\n\t\tint inputValue = sc.nextInt();\n\t\treturn inputValue;\n\t}", "@Test(priority = 2)\r\n\tpublic void getresponse(){\n\t\t\r\n\t\tString resData = get(\"http://samples.openweathermap.org/data/2.5/weather?q=London,uk&appid=b6907d289e10d714a6e88b30761fae22\").asString();\t\r\n\t\tSystem.out.println(resData);\r\n\t\t\r\n\t\tlong time = get(\"\").getTime();\r\n\t\t\r\n\t\tSystem.out.println(\"Response time \" + time);\r\n\t}", "private static Temperature getNewTemperature() {\n System.out.println(\"Enter an initial temperature reading, which\");\n System.out.print(\"should be a number optionally followed by C or F: \"); \n String response = input.nextLine().trim(); \n if (echo) { System.out.println(response); }\n double initVal = parseOutNum(response);\n char scale = Character.toUpperCase(parseOutScale(response));\n\n if (scale == CEL_SCALE_CODE) { \n System.out.printf(\"Calling Temperature(%f,true)\\n\", initVal);\n return new Temperature(initVal, true);\n }\n else if (scale == FAH_SCALE_CODE) {\n System.out.printf(\"Calling Temperature(%f,false)\\n\", initVal);\n return new Temperature(initVal, false);\n }\n else { // no scale indicated\n System.out.printf(\"Calling Temperature(%f)\\n\", initVal);\n return new Temperature(initVal);\n }\n }", "private void findHumidities(ForecastIO FIO, WeatherlyDayForecast day){\n FIOHourly hourlyForecast = new FIOHourly(FIO);\n int numHours = hourlyForecast.hours();\n\n //Determine the number of hours left in the day\n Calendar rightNow = Calendar.getInstance();\n int dayHoursLeft = 24 - rightNow.get(Calendar.HOUR_OF_DAY);\n\n //Find the lowest and highest chances for precipitation for the rest of the day\n double minHum = hourlyForecast.getHour(0).humidity();\n double maxHum = minHum;\n int maxHour = rightNow.get(Calendar.HOUR_OF_DAY);\n for (int i = 1; i < dayHoursLeft; i++){\n double hum = hourlyForecast.getHour(i).humidity();\n if (minHum > hum)\n minHum = hum;\n if (maxHum < hum) {\n maxHum = hum;\n maxHour = i + rightNow.get(Calendar.HOUR_OF_DAY);\n }\n\n }\n\n day.setHumMin((int) (minHum * 100));\n day.setHumMax((int) (maxHum * 100));\n day.setHumMaxTime(maxHour);\n }", "public ArrayList<Weather> getDarkSkyWeather(String longitude, String latitude) {\n\n Log.i(\"long: \", longitude);\n Log.i(\"lat: \", latitude);\n\n Weather weather = new Weather();\n ArrayList<Weather> weatherArr = new ArrayList<Weather>();\n ArrayList<String> temp = new ArrayList<String>();\n String content;\n try {\n content = weather.execute(\"https://api.darksky.net/forecast/a4b289aa3abfbee48b4fc1df98208a34/\"+ latitude + \",\" + longitude + \"?lang=vi&exclude=minutely,flags,currently\").get();\n\n if(content == null)\n {\n return null;\n }\n JSONObject obj = new JSONObject(content);\n\n JSONObject daily = obj.getJSONObject(\"daily\");\n JSONArray dataDaily = daily.getJSONArray(\"data\");\n\n String summary;\n String temperatureMin;\n String temperatureMax;\n String humidity;\n String windSpeed;\n String windGust;\n String airPressure;\n String visibility;\n String ozoneDensity;\n String uvIndex;\n String cloudCover;\n String precipProbability;\n String time;\n\n Bundle bundle2 = new Bundle();\n images = new Integer[dataDaily.length()];\n\n for(int i = 0; i < dataDaily.length(); i++)\n {\n Weather result = new Weather();\n\n JSONObject detail = dataDaily.getJSONObject(i);\n\n summary = detail.getString(\"summary\");\n temperatureMin = detail.getString(\"temperatureMin\");\n temperatureMax = detail.getString(\"temperatureMax\");\n precipProbability = detail.getString(\"precipProbability\");\n humidity = detail.getString(\"humidity\");\n windSpeed = detail.getString(\"windSpeed\");\n windGust = detail.getString(\"windGust\");\n airPressure = detail.getString(\"pressure\");\n visibility = detail.getString(\"visibility\");\n ozoneDensity = detail.getString(\"ozone\");\n uvIndex = detail.getString(\"uvIndex\");\n cloudCover = detail.getString(\"cloudCover\");\n time = unixTimeToDate(detail.getString(\"time\"));\n\n\n String precipProb = String.valueOf(String.format(\"%.0f\", (Float.parseFloat(precipProbability)*100))+ \"%\");\n\n // Update UI\n result.setDate(normalizeDate(time.substring(0, 10)));\n result.setWeather(summary);\n result.setDescription(\"Khả năng mưa: \" + precipProb);\n result.setTemperature(celsiusToFahrenheit(temperatureMax) + \"\\u2103\");\n result.setWind(\"Gió: \" + windSpeed + \"mph\");\n weatherArr.add(result);\n\n if(summary.toLowerCase().contains(\"quang\"))\n {\n images[i] = R.drawable.sunny;\n }\n if(summary.toLowerCase().contains(\"mưa\"))\n {\n images[i] = R.drawable.rainy;\n }\n else if (summary.toLowerCase().contains(\"âm u\"))\n {\n images[i] = R.drawable.foggy;\n }\n else if (summary.toLowerCase().contains(\"mây\"))\n {\n images[i] = R.drawable.cloudy;\n }\n else\n {\n images[i] = R.drawable.sunny;\n }\n\n\n// Bundle bundlee = new Bundle();\n// ArrayList<String> dailyData = new ArrayList<String>();\n//\n// dailyData.add(summary);\n// dailyData.add(precipProb);\n// dailyData.add(normalizeDate(time.substring(0, 10)));\n// dailyData.add(temperatureMin +\"\\u2103\");\n// dailyData.add(temperatureMax +\"\\u2103\");\n// dailyData.add(humidity + \"%\");\n// dailyData.add(windSpeed + \" mph\");\n// dailyData.add(windGust + \" mph\");\n// dailyData.add(airPressure + \" mb\");\n// dailyData.add(visibility + \" mi\");\n// dailyData.add(ozoneDensity + \" DU\");\n// dailyData.add(uvIndex);\n// dailyData.add(cloudCover);\n// dailyData.add(String.valueOf(i)); // fragment-tag\n//\n// bundlee.putStringArrayList(\"daily-data\",dailyData);\n\n\n Bundle bundle = new Bundle();\n bundle.putString(\"weather\", summary);\n bundle.putString(\"PoP\", precipProb);\n bundle.putString(\"date\", normalizeDate(time.substring(0, 10)));\n bundle.putString(\"tempMin\", temperatureMin +\"\\u2103\");\n bundle.putString(\"tempMax\", temperatureMax +\"\\u2103\");\n bundle.putString(\"humidity\", humidity + \"%\");\n bundle.putString(\"windSpeed\", windSpeed + \" mph\");\n bundle.putString(\"winGust\", windGust + \" mph\");\n bundle.putString(\"airPressure\", airPressure + \" mb\");\n bundle.putString(\"visibility\", visibility + \" mi\");\n bundle.putString(\"ozoneDensity\", ozoneDensity + \" DU\");\n bundle.putString(\"uvIndex\", uvIndex);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTag\", String.valueOf(i));\n\n temp.add(temperatureMin);\n\n bundleDailyArr.add(bundle);\n// bundleDailyArr.add(bundlee);\n\n// Log.i(\"Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n for(int i = 0; i < temp.size(); i++)\n {\n bundle2.putString(\"temp\"+String.valueOf(i), temp.get(i));\n }\n\n\n\n// Get weather hourly\n\n JSONObject hourly = obj.getJSONObject(\"hourly\");\n JSONArray dataHourly = hourly.getJSONArray(\"data\");\n String temperature;\n\n for(int i = 0; i < dataHourly.length(); i++)\n {\n JSONObject detail = dataHourly.getJSONObject(i);\n\n temperature = detail.getString(\"temperature\");\n precipProbability = detail.getString(\"precipProbability\");\n windSpeed = detail.getString(\"windSpeed\");\n cloudCover = detail.getString(\"cloudCover\");\n\n Bundle bundle = new Bundle();\n bundle.putString(\"PoP\", precipProbability);\n //bundle.putString(\"temp\", String.valueOf((int)(Float.parseFloat(temperatureMin) + Float.parseFloat(temperatureMax) / 2)));\n bundle.putString(\"temperature\", temperature);\n bundle.putString(\"windSpeed\", windSpeed);\n bundle.putString(\"cloudCover\", cloudCover);\n bundle.putString(\"fragmentTagasd\", String.valueOf(i));\n\n\n bundleHourlyArr.putBundle(String.valueOf(i),bundle);\n\n\n Log.i(\"Hourly Index: \", String.valueOf(i));\n// Log.i(\"summary :\", summary);\n// Log.i(\"temperatureMin :\", temperatureMin);\n// Log.i(\"temperatureMax :\", temperatureMax);\n// Log.i(\"humidity :\", humidity);\n// Log.i(\"windSpeed :\", windSpeed);\n// Log.i(\"winGust :\", windGust);\n// Log.i(\"airPressure :\", airPressure);\n// Log.i(\"visibility :\", visibility);\n// Log.i(\"ozoneDensity :\", ozoneDensity);\n// Log.i(\"uvIndex :\", uvIndex);\n// Log.i(\"cloudCover :\", cloudCover);\n// Log.i(\"cloudCover :\", \"\\n\");\n// Log.i(\"precipProbability :\", precipProbability);\n }\n\n } catch (Exception e) {\n e.printStackTrace();\n }\n\n return weatherArr;\n }", "public void setContainerTemperature2(double value) {\r\n this.containerTemperature2 = value;\r\n }", "public double getHumidity()\n {\n return humidity;\n }", "public double getTemperature(int frame, int res_cent) {\r\n\t\tdouble tempSpeed = this.getSpeed(frame, res_cent);\r\n\t\tdouble tempSpeed2 = tempSpeed * tempSpeed;\r\n\t\tdouble mass = 0.002; //kilogram per mole, assumed as 0.002 (2g/mol)\r\n\t\tdouble gas_constant = 8.314;// unit: J/(mol * K)\r\n\t\t\r\n\t\t//Apply the equation\r\n\t\tdouble temperatureK = tempSpeed2 * mass / gas_constant /3;\r\n\t\t\r\n\t\t//Apply logarithm to convert it to celcius\r\n\t\t//this is not an exact method but the speed of particles are\r\n\t\t//much slower than the gas particles in real life\r\n\t\tdouble temperatureC = Math.log(1000000*temperatureK);\r\n\t\t\r\n\t\treturn temperatureC ;\r\n\t}" ]
[ "0.6486162", "0.62194675", "0.6147765", "0.6088238", "0.60777277", "0.5875585", "0.5821438", "0.5771365", "0.5739417", "0.5712987", "0.5703749", "0.56953585", "0.5693092", "0.5623461", "0.561041", "0.5584853", "0.5561301", "0.5559038", "0.55310404", "0.553048", "0.55013454", "0.54445636", "0.54332024", "0.5427766", "0.5416039", "0.53717214", "0.5357097", "0.5355766", "0.53456", "0.5344573", "0.5342106", "0.53241855", "0.5306779", "0.53058666", "0.530467", "0.52964664", "0.5277809", "0.5275488", "0.52687716", "0.52667385", "0.5265107", "0.5254109", "0.5249103", "0.5246816", "0.52423084", "0.5231955", "0.5231597", "0.52248937", "0.5211957", "0.5209934", "0.51908904", "0.5186053", "0.51714003", "0.51565224", "0.51515716", "0.5142054", "0.5125646", "0.51244575", "0.51159394", "0.5114285", "0.51069325", "0.51052463", "0.50892854", "0.5078783", "0.50787723", "0.50775623", "0.50695586", "0.50577927", "0.5051606", "0.50488394", "0.5018339", "0.5015182", "0.4997864", "0.49920532", "0.4988336", "0.49883187", "0.49847132", "0.49829686", "0.49548224", "0.4953876", "0.49537846", "0.49501148", "0.49453375", "0.49432933", "0.49407935", "0.4939396", "0.49378985", "0.49372932", "0.4936392", "0.49330658", "0.4929963", "0.49286038", "0.49250987", "0.49205106", "0.49034342", "0.48785302", "0.4873106", "0.4869361", "0.48693216", "0.48666474" ]
0.6653388
0
Created by cdsm16 on 04/10/2016.
public interface ChannelREST { public static final String ENDPOINT = "http://92.222.72.89:8080/"; @GET("/club/{idClub}/channels/{idChannel}/messages") Call<List<Message>> getAllMessageFromChannel(@Path("idClub") Integer id, @Path("idChannel") Integer idChannel); @GET("/club/{idClub}/channels") Call<List<Channel>> getAllChannelFromClub(@Path("idClub") Integer id); @FormUrlEncoded @POST("/club/{idClub}/channels/{idChannel}/postMessage") Call<Message> postMessage(@Path("idClub") Integer id, @Path("idChannel") Integer idChannel, @Field("idUser") Integer idUser, @Field("content")String content); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void perish() {\n \n }", "private stendhal() {\n\t}", "@Override\n\tpublic void comer() {\n\t\t\n\t}", "@Override\n\tpublic void grabar() {\n\t\t\n\t}", "@Override\r\n\tpublic void tires() {\n\t\t\r\n\t}", "public final void mo51373a() {\n }", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void bicar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void comer() \r\n\t{\n\t\t\r\n\t}", "@Override\n public void init() {\n\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n protected void initialize() {\n }", "@Override\n\tpublic void entrenar() {\n\t\t\n\t}", "@Override\n protected void initialize() {\n\n \n }", "@Override\n\tprotected void interr() {\n\t}", "@Override\r\n\tpublic void dormir() {\n\t\t\r\n\t}", "@Override\r\n\t\t\tpublic void annadir() {\n\r\n\t\t\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\n\tprotected void initialize() {\n\t\t\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void dibujar() {\n\t\t\r\n\t}", "@Override\r\n\t\tpublic void init() {\n\t\t\t\r\n\t\t}", "@Override\n\tpublic void anular() {\n\n\t}", "@Override\n public void init() {\n }", "@Override\n public void func_104112_b() {\n \n }", "@Override\n protected void initialize() \n {\n \n }", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n\tpublic void init() {\n\t\t\n\t}", "@Override\n void init() {\n }", "@Override\n\tprotected void initialize() {\n\n\t}", "@Override\n public int describeContents() { return 0; }", "@Override\n\tpublic void sacrifier() {\n\t\t\n\t}", "@Override\n\tprotected void getExras() {\n\n\t}", "@Override\n public void init() {}", "public void mo38117a() {\n }", "@Override\n protected void init() {\n }", "@Override\r\n\tpublic void anularFact() {\n\t\t\r\n\t}", "@Override\n\tpublic void gravarBd() {\n\t\t\n\t}", "@Override\r\n\tpublic void rozmnozovat() {\n\t}", "@Override\r\n\tpublic void init() {}", "@Override\r\n\tprotected void initialize() {\r\n\t\t\r\n\t\t\r\n\t}", "@Override\n public void init() {\n\n }", "@Override\n public void init() {\n\n }", "@Override\n public void initialize() { \n }", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void init() {\n\n\t}", "@Override\n\tpublic void one() {\n\t\t\n\t}", "public void gored() {\n\t\t\n\t}", "protected MetadataUGWD() {/* intentionally empty block */}", "@Override\n\tprotected void initialize() {\n\t}", "@Override\n\tprotected void initialize() {\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\t\t\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tpublic void init() {\n\r\n\t}", "@Override\r\n\tprotected void initialize() {\n\r\n\t}", "private void init() {\n\n\t}", "@Override\n public void initialize() {}", "@Override\n public void initialize() {}", "@Override\n public void initialize() {}", "@Override\n\tpublic void nghe() {\n\n\t}", "@Override\r\n\t\t\tpublic void ayuda() {\n\r\n\t\t\t}", "public void mo4359a() {\n }", "@Override\n\tpublic void debite() {\n\t\t\n\t}", "@Override\n\tpublic void jugar() {\n\t\t\n\t}", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "private void m50366E() {\n }", "@Override\n\tpublic void init() {\n\t}", "@Override\r\n\tpublic void init()\r\n\t{\n\t}", "private Rekenhulp()\n\t{\n\t}", "@Override\n\tpublic void init()\n\t{\n\n\t}", "@Override\n public void initialize() {\n \n }", "@Override\n\t\tpublic void init() {\n\t\t}", "private static void cajas() {\n\t\t\n\t}", "@Override\n protected void getExras() {\n }", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n public void inizializza() {\n\n super.inizializza();\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "public void mo55254a() {\n }", "protected boolean func_70814_o() { return true; }", "private void poetries() {\n\n\t}", "Constructor() {\r\n\t\t \r\n\t }", "@Override\n public void memoria() {\n \n }", "@Override\n public void initialize() {\n }", "@Override\n public void initialize() {\n }" ]
[ "0.6124494", "0.5924772", "0.5894605", "0.58572346", "0.58283144", "0.5823064", "0.57916456", "0.57916456", "0.57685775", "0.5696636", "0.56893337", "0.56893337", "0.56893337", "0.56893337", "0.56893337", "0.56893337", "0.56892145", "0.5687091", "0.5669871", "0.56654334", "0.56527346", "0.56448", "0.5637918", "0.5637918", "0.5622044", "0.5622044", "0.5615518", "0.5612494", "0.561208", "0.56050205", "0.56014514", "0.5595203", "0.5595203", "0.5595203", "0.5595203", "0.5595203", "0.55812377", "0.5573746", "0.55728084", "0.55712837", "0.5570746", "0.5554675", "0.55413294", "0.552753", "0.5525544", "0.5517965", "0.5512536", "0.5508949", "0.5508171", "0.5489651", "0.5489651", "0.5482513", "0.5475926", "0.5475926", "0.5475926", "0.54726195", "0.54723984", "0.5465952", "0.54654753", "0.54654753", "0.54620874", "0.54620874", "0.54620874", "0.5448835", "0.5448835", "0.5448835", "0.5447368", "0.5439091", "0.54389024", "0.54389024", "0.54389024", "0.5434186", "0.5431393", "0.5430443", "0.54273826", "0.54260576", "0.5424784", "0.5422439", "0.5412715", "0.54046065", "0.53907585", "0.5375482", "0.5364579", "0.53588957", "0.53562546", "0.534904", "0.534573", "0.53344727", "0.53335905", "0.53335905", "0.53335905", "0.53335905", "0.53335905", "0.53335905", "0.53335905", "0.5332934", "0.5331029", "0.5322385", "0.53222543", "0.5318149", "0.5318149" ]
0.0
-1
/ RestTemplate rt=new RestTemplate(); ResponseEntity response = rt.getForEntity((" String.class); System.out.println(response);
@RequestMapping("/getUsers") public String getUsers() { return "Hai Hello How are you"; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public static void getMethodTest()\n\t{\n String content = restTemplate.getForObject(baseURL+\"/hello\", String.class);\n System.out.println(\"-------------\");\n \n ResponseEntity<String > s = restTemplate.getForEntity(baseURL+\"/hello\", String.class);\n System.out.println(s.getBody());\n System.out.println(s.getStatusCodeValue());\n System.out.println(s.getHeaders());\n System.out.println(s.getStatusCode());\n\n\t}", "public RestTemplate getRestTemplate();", "public static void main(String[] args) {\n RestTemplate restTemplate = new RestTemplateBuilder()\n .rootUri(\"http://localhost:8080/api/v1/students\")\n .basicAuthorization(\"joao_silva\",\"jpp123456\")\n .build();\n Student student = restTemplate.getForObject(\"/{id}\", Student.class, 1);\n ResponseEntity<Student> forEntity = restTemplate.getForEntity(\"/{id}\",Student.class,1);\n System.out.println(student);\n System.out.println(forEntity.getBody());\n Student[] students = restTemplate.getForObject(\"/\", Student[].class);\n System.out.println(Arrays.toString(students));\n ResponseEntity<List<Student>> exchange = restTemplate.exchange(\"/\", HttpMethod.GET, null, new ParameterizedTypeReference<List<Student>>() {\n });\n System.out.println(exchange.getBody());\n\n\n\n }", "private RestTemplate getRestTemplate() {\n ObjectMapper mapper = new ObjectMapper();\n mapper.configure(DeserializationFeature.FAIL_ON_UNKNOWN_PROPERTIES, false);\n mapper.registerModule(new Jackson2HalModule());\n\n MappingJackson2HttpMessageConverter converter = new MappingJackson2HttpMessageConverter();\n converter.setSupportedMediaTypes(MediaType.parseMediaTypes(\"application/haljson,*/*\"));\n converter.setObjectMapper(mapper);\n\n return new RestTemplate(Collections.<HttpMessageConverter<?>>singletonList(converter));\n }", "@Test\r\n\tpublic void givenResourceUrl_whenSendGetForRequestEntity_thenStatusOk() throws IOException {\n\r\n\t\tfinal Logger log = LoggerFactory.getLogger(UserDataRestTemplateTest.class);\r\n\r\n\t\tRestTemplate restTemplate = new RestTemplate();\r\n\t\tMap<String, String> response = (Map<String, String>) restTemplate\r\n\t\t\t\t.getForObject(\"http://services.groupkt.com/country/get/iso2code/IN\", Map.class);\r\n\t\tlog.info(\"==== RESTful API Response using Spring RESTTemplate START =======\");\r\n\t\tlog.info(response.toString());\r\n\t\tlog.info(\"==== RESTful API Response using Spring RESTTemplate END =======\");\r\n\r\n\t}", "public void testGetInvoicesusingRestNEW() throws Exception\r\n {\r\n String url = BASE_URL + \"/rest/user/userId/1\";\r\n\r\n Object test = restTemplate.getForEntity(url, UserEntity.class);\r\n\r\n System.out.println(\"=======================================================================\");\r\n System.out.println(\"testRetrieveUserJSON: test=\" + test);\r\n System.out.println(\"=======================================================================\");\r\n }", "private static void get() throws IOException {\n\n\n RestTemplate restTemplate = new RestTemplate();\n\n HttpHeaders headers = new HttpHeaders();\n InputStream inputStream = null;\n OutputStream outputStream = null;\n try {\n List<MediaType> list = new ArrayList<>();\n list.add(MediaType.APPLICATION_OCTET_STREAM);\n headers.setAccept(list);\n\n ResponseEntity<byte[]> response = restTemplate.exchange(\n url,\n HttpMethod.GET,\n new HttpEntity<byte[]>(headers),\n byte[].class);\n\n byte[] result = response.getBody();\n\n inputStream = new ByteArrayInputStream(result);\n\n File file = new File(\"C:\\\\Users\\\\chen.shuodong\\\\Desktop\\\\123.jpg\");\n if (!file.exists())\n {\n file.createNewFile();\n }\n\n outputStream = new FileOutputStream(file);\n int len = 0;\n byte[] buf = new byte[1024];\n while ((len = inputStream.read(buf, 0, 1024)) != -1) {\n outputStream.write(buf, 0, len);\n }\n outputStream.flush();\n\n }finally {\n if(inputStream != null){\n inputStream.close();\n }\n if(outputStream != null){\n outputStream.close();\n }\n }\n }", "@Bean\n\tRestTemplate getRestTemplate() {\n\t\treturn new RestTemplate();\n\t}", "@GetMapping(path=\"/json\")\n public String getTodos() {\n String theUrl = \"http://localhost:8080/hello\";\n ResponseEntity<String> response = restTemplate.exchange(theUrl, HttpMethod.GET, null, String.class);\n\n return response.getBody();\n }", "@Test\n\tpublic void listAllFornecedor() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new FornecedorInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tFornecedorResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/fornecedor/fetchPage/\",\n\t\t\t\tentitys, FornecedorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getFornecedorList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertFornecedor(id, TabelaEnum.FORNECEDOR, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"fornecedor\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/fornecedor/insert/\", entitys,\n\t\t\t\tFornecedorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertFornecedor(id, TabelaEnum.FORNECEDOR, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"fornecedor\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/fornecedor/update/\", entitys,\n\t\t\t\tFornecedorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tFornecedorInquiryRequest request001 = new FornecedorInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/fornecedor/fetchPage/\", entitys,\n\t\t\t\tFornecedorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getFornecedorList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getFornecedorList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFornecedorList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFornecedorList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFornecedorList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFornecedorList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertFornecedor(id, TabelaEnum.FORNECEDOR, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"fornecedor\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/fornecedor/delete/\", entitys,\n\t\t\t\tFornecedorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getFornecedorList().size(), count.intValue());\n\n\t}", "@Bean\n RestTemplate restTemplate(){\n return new RestTemplate();\n }", "@Test\n public void shouldGetMessage() {\n ResponseEntity<AppModel> response = restTemplate.getForEntity(format(\"%s?message=hello world\", BASE_URL), AppModel.class, \"\");\n assertEquals(OK, response.getStatusCode());\n }", "private RestTemplate getRestTemplateForPatch() {\n HttpComponentsClientHttpRequestFactory requestFactory = new HttpComponentsClientHttpRequestFactory();\n return new RestTemplate(requestFactory);\n }", "public String getAPI()\n {\n ResponseEntity<String> person;\n\n /*\n\t\t * Headers for the response type if we want to return JSON response then we\n\t\t * require to add.\n */\n HttpHeaders headers = new HttpHeaders();\n\n /*\n\t\t * Adding of the response header with application/json type\n */\n headers.add(\"Accept\", \"application/json\");\n\n /*\n\t\t * Creation of the Entity object for the adding the headers into request.\n */\n entity = new HttpEntity<>(headers);\n\n /*\n\t\t * Creation of REST TEMPLET object for the executing of the REST calls.\n */\n restTemplate = new RestTemplate();\n\n /*\n\t\t * Adding the basic type of authentication on the REST TEMPLETE.\n */\n restTemplate.getInterceptors()\n .add(new BasicAuthorizationInterceptor(\"Administrator\", \"Oneeight@admin18\"));\n\n /*\n\t\t * Execution of the REST call with basic authentication and JSON response type\n */\n person = restTemplate.exchange(\"http://52.172.222.197:8080/versa/login?username=Administrator&password=Oneeight@admin18\", HttpMethod.POST, entity, String.class);\n System.out.println(\"\"+person.toString());\n //headers.add(\"Cookie\", \"JSESSIONID=0FC37952D64B545C46969EFEC0E4FD12\");\n headers.add(\"Cookie\", person.getHeaders().getFirst(HttpHeaders.SET_COOKIE));\n entity = new HttpEntity<>(headers);\n person = restTemplate.exchange(\"http://52.172.222.197:8080/versa/analytics/v1.0.0/data/provider/tenants/OneEight/features/SDWAN/?qt=summary&start-date=1daysAgo&end-date=today&q=linkusage(site)&metrics=volume-rx&metrics=volume-tx&metrics=volume-rx&metrics=volume-tx&metrics=bandwidth&ds=aggregate&count=10\", HttpMethod.GET, entity, String.class);\n\n /*\n\t\t * Returning the response body with string format that easily readable.\n */\n return person.getBody();\n }", "@Bean\n public RestTemplate restTemplate(){\n return new RestTemplate();\n }", "@Test(expected = ResourceAccessException.class)\n public void testReturnBookTransaction(){\n HttpEntity<Object> transaction = getHttpEntity(\n \"\");\n\n ResponseEntity<Transaction> response = template.exchange(\n \"/api/transaction/6/return\", HttpMethod.PATCH,transaction,Transaction.class);\n\n\n Assert.assertEquals(200,response.getStatusCode().value());\n\n }", "@Bean\n\tpublic RestTemplate restTemplate() {\n\t\treturn new RestTemplate();\n\t}", "@Test\n public void test_getFacilities() throws Exception {\n ResponseEntity<FacilityResponse> response = restTemplate.getForEntity(\"/v1/facilities\", FacilityResponse.class);\n\n // assert\n Assertions.assertThat(response.getStatusCode()).isEqualTo(HttpStatus.OK);\n Assertions.assertThat(Collections.singletonList(Objects.requireNonNull(response.getBody()).getFacilities()));\n Assertions.assertThat(response.getBody().getFacilities().get(0).getName()).isEqualTo(\"p1\");\n // response structure: //{\"facilities\":[{\"id\":101,\"name\":\"p1\",\"address\":\"testAddress\"}]}\n }", "@Test\n\tpublic void listAllAdvogado() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new AdvogadoInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tAdvogadoResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/advogado/fetchPage/\",\n\t\t\t\tentitys, AdvogadoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getAdvogadoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertAdvogado(id, TabelaEnum.ADVOCACIA, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"advogado\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/advogado/insert/\", entitys,\n\t\t\t\tAdvogadoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertAdvogado(id, TabelaEnum.ADVOCACIA, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"advogado\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/advogado/update/\", entitys,\n\t\t\t\tAdvogadoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tAdvogadoInquiryRequest request001 = new AdvogadoInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/advogado/fetchPage/\", entitys,\n\t\t\t\tAdvogadoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getAdvogadoList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getAdvogadoList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getAdvogadoList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getAdvogadoList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getAdvogadoList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t// //Assert.assertEquals(result.getAdvogadoList().get(0).getEstadoCivil(),(1005);\n\t\t// //Assert.assertEquals(result.getAdvogadoList().get(0).getTipoPessoa(),(1006);\n\t\t// //Assert.assertEquals(result.getAdvogadoList().get(0).getDatanasc(),(new\n\t\t// Long());\n\t\t//Assert.assertEquals(result.getAdvogadoList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\t\t// //Assert.assertEquals(result.getAdvogadoList().get(0).getPessoaTypeEnum(),(1009);\n\t\t// //Assert.assertEquals(result.getAdvogadoList().get(0).getSexo(),(1010);\n\t\t// objeto.setEnderecos(new ArrayList<List<Endereco>> ())\n\t\t// objeto.get().add(new List<Endereco>());\n\t\t// objeto.setDocumentos(new ArrayList<List<Documento>> ())\n\t\t// objeto.get().add(new List<Documento>());\n\t\t// objeto.setEmails(new ArrayList<List<Email>> ())\n\t\t// objeto.get().add(new List<Email>());\n\t\t// objeto.setTelefones(new ArrayList<List<Telefone>> ())\n\t\t// objeto.get().add(new List<Telefone>());\n\t\t// objeto.setBancos(new ArrayList<List<BancoPessoa>> ())\n\t\t// objeto.get().add(new List<BancoPessoa>());\n\t\t// objeto.setFormaPagamentoList(new ArrayList<List<FormaPgPessoa>> ())\n\t\t// objeto.get().add(new List<FormaPgPessoa>());\n\t\t// objeto.setCondPagList(new ArrayList<List<CondPagPessoa>> ())\n\t\t// objeto.get().add(new List<CondPagPessoa>());\n\t\t// objeto.setContatoList(new ArrayList<List<Contato>> ())\n\t\t// objeto.get().add(new List<Contato>());\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertAdvogado(id, TabelaEnum.ADVOCACIA, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"advogado\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/advogado/delete/\", entitys,\n\t\t\t\tAdvogadoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getAdvogadoList().size(), count.intValue());\n\n\t}", "public void testGetInvoicesusingRest() throws Exception\r\n {\r\n String url = BASE_URL + \"/rest/pendingInvoices/searchAndCount/\";\r\n\r\n Object test = restTemplate.getForEntity(url, UserEntity.class);\r\n\r\n System.out.println(\"=======================================================================\");\r\n System.out.println(\"testRetrieveUserJSON: test=\" + test);\r\n System.out.println(\"=======================================================================\");\r\n }", "@Test\n\tpublic void listAllCliente() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new ClienteInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tClienteResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/fetchPage/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getClienteList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertCliente(id, TabelaEnum.CLIENTE, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"cliente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/insert/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t//\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(new ClienteInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/fetchPage/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getClienteList().size();\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertCliente(id, TabelaEnum.CLIENTE, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"cliente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/update/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tClienteInquiryRequest request001 = new ClienteInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/fetchPage/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getClienteList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getClienteList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getClienteList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getClienteList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getClienteList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getClienteList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertCliente(id, TabelaEnum.CLIENTE, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"cliente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/cliente/delete/\", entitys,\n\t\t\t\tClienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getClienteList().size(), count.intValue());\n\n\t}", "@Autowired\r\n\tpublic RestTemplate restTemplate() throws KeyStoreException, NoSuchAlgorithmException, KeyManagementException {\n\t TrustStrategy acceptingTrustStrategy = (X509Certificate[] chain, String authType) -> true;\r\n\t //Create SSLContext with null key store and override.\r\n\t SSLContext sslContext = org.apache.http.ssl.SSLContexts.custom().loadTrustMaterial(null, acceptingTrustStrategy).build();\r\n\t //Remember the NoopHostNameVerifier for nothrow of alternate name SSLException\r\n\t SSLConnectionSocketFactory csf = new SSLConnectionSocketFactory(sslContext, NoopHostnameVerifier.INSTANCE);\r\n\t CloseableHttpClient httpClient = HttpClients.custom().setSSLSocketFactory(csf).build();\r\n\t //Set httpclient with custom ssl verification inside request factory.\r\n\t HttpComponentsClientHttpRequestFactory requestFactory = new HttpComponentsClientHttpRequestFactory(httpClient);\r\n\t //Return rest template with custom requestfactory.\r\n\t RestTemplate restTemplate = new RestTemplate(requestFactory);\r\n\t return restTemplate;\r\n\t }", "@Test\n public void shouldGetParkingList() throws Exception {\n Mockito.when(restTemplate.getForObject(anyString(), any())).thenReturn(response);\n\n String expectedResponse = \"/expected_parkingList_response.json\";\n ClassPathResource expectedResultPath = new ClassPathResource(expectedResponse, this.getClass().getClassLoader());\n String expectedResult = StreamUtils.copyToString( expectedResultPath.getInputStream(), Charset.defaultCharset());\n\n String uri = \"/parkings\";\n\n mockMvc.perform(get(uri))\n /*.andDo(print())*/\n .andExpect(content().contentType(APPLICATION_JSON_VALUE))\n .andExpect(status().isOk())\n .andExpect(content().string(expectedResult));\n\n }", "@Test\n\tpublic void listAllBoleto() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tBoletoResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/boleto/fetchPage/\",\n\t\t\t\tentitys, BoletoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getBoletoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertBoleto(id, TabelaEnum.BOLETO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"boleto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/boleto/insert/\", entitys,\n\t\t\t\tBoletoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertBoleto(id, TabelaEnum.BOLETO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"boleto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/boleto/update/\", entitys,\n\t\t\t\tBoletoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/boleto/fetchPage/\", entitys,\n\t\t\t\tBoletoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getBoletoList().size(), 1);\n\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getAtivarBolOnLine(),(1001);\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getTipoBoleto(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getAgencia(),(1003);\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getCedente(),(1004);\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getJuros(),(10.00);\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getTipoCalcMora(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getMora(),(10.00);\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getInstrucoes(),\"\"instrucoes_8\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getDemonstrativo(),\"\"demonstrativo_9\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getBoletoList().get(0).getImpJuros(),(1010);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertBoleto(id, TabelaEnum.BOLETO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"boleto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/boleto/delete/\", entitys,\n\t\t\t\tBoletoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getBoletoList().size(), count.intValue());\n\n\t}", "@Test\n\tpublic void listAllInquilino() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new InquilinoInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tInquilinoResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/inquilino/fetchPage/\",\n\t\t\t\tentitys, InquilinoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getInquilinoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertInquilino(id, TabelaEnum.INQUILINO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"inquilino\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/inquilino/insert/\", entitys,\n\t\t\t\tInquilinoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertInquilino(id, TabelaEnum.INQUILINO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"inquilino\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/inquilino/update/\", entitys,\n\t\t\t\tInquilinoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tInquilinoInquiryRequest request001 = new InquilinoInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/inquilino/fetchPage/\", entitys,\n\t\t\t\tInquilinoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getInquilinoList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getInquilinoList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getInquilinoList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getInquilinoList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getInquilinoList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getInquilinoList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertInquilino(id, TabelaEnum.INQUILINO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"inquilino\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/inquilino/delete/\", entitys,\n\t\t\t\tInquilinoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getInquilinoList().size(), count.intValue());\n\n\t}", "@Test\n\tpublic void testPatient() {\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\tHttpEntity<String> entity = new HttpEntity<String>(null, headers);\n\t\tResponseEntity<String> response = restTemplate.exchange(getRootUrl() + \"/edit-patient?id=4\",HttpMethod.GET, entity, String.class);\n\t\tassertEquals(200,response.getStatusCodeValue());\n\t}", "@Test\n\tpublic void listAllConfigSMTP() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigSMTPResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configSMTP/fetchPage/\", entitys, ConfigSMTPResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigSMTPList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertConfigSMTP(id, TabelaEnum.CONFIGSMTP, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configSMTP\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configSMTP/insert/\", entitys,\n\t\t\t\tConfigSMTPResponse.class);\n\t\t// Assert.assertEquals(result.isOperationSuccess(), false);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertConfigSMTP(id, TabelaEnum.CONFIGSMTP, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configSMTP\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configSMTP/update/\", entitys,\n\t\t\t\tConfigSMTPResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configSMTP/fetchPage/\", entitys,\n\t\t\t\tConfigSMTPResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t//\tAssert.assertEquals(result.getConfigSMTPList().size(), 4);\n\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getServSMTP(),\"\"servSMTP_1\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getPorta(),\"\"porta_2\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getEndEmail(),\"\"endEmail_3\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getUsuario(),\"\"usuario_4\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getSenha(),\"\"senha_5\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigSMTPList().get(0).getSeguranca(),(new\n\t\t// DoisValores());\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertConfigSMTP(id, TabelaEnum.CONFIGSMTP, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configSMTP\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configSMTP/delete/\", entitys,\n\t\t\t\tConfigSMTPResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigSMTPList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void listAllSindico() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new SindicoInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tSindicoResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/sindico/fetchPage/\", entitys,\n\t\t\t\tSindicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getSindicoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertSindico(id, TabelaEnum.SINDICO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"sindico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/sindico/insert/\", entitys,\n\t\t\t\tSindicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertSindico(id, TabelaEnum.SINDICO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"sindico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/sindico/update/\", entitys,\n\t\t\t\tSindicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tSindicoInquiryRequest request001 = new SindicoInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/sindico/fetchPage/\", entitys,\n\t\t\t\tSindicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getSindicoList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getSindicoList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getSindicoList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getSindicoList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getSindicoList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getSindicoList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertSindico(id, TabelaEnum.SINDICO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"sindico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/sindico/delete/\", entitys,\n\t\t\t\tSindicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getSindicoList().size(), count.intValue());\n\n\t}", "@Override\n @Bean\n public CommandLineRunner run(RestTemplate restTemplate) throws Exception {\n HttpHeaders headers = new HttpHeaders();\n headers.set(\"Accept\", \"application/json\");\n return args -> {\n result = restTemplate.exchange(GlobalCovidRestData.URL, HttpMethod.GET,\n new HttpEntity<String>(headers), String.class);\n log.info(result.toString());\n };\n\n }", "@Test\n\tpublic void listAllConfigGeral() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigGeralResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configGeral/fetchPage/\", entitys, ConfigGeralResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigGeralList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigGeral(id, TabelaEnum.CONFIGGERAL, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configGeral\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configGeral/insert/\", entitys,\n\t\t\t\tConfigGeralResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigGeral(id, TabelaEnum.CONFIGGERAL, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configGeral\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configGeral/update/\", entitys,\n\t\t\t\tConfigGeralResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configGeral/fetchPage/\", entitys,\n\t\t\t\tConfigGeralResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getConfigGeralList().size(), 20);\n\t\t//\n\t\t//\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getFusoHorario(),(1001);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getCasasDecimais(),(1002);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getDiasCartaCobr(),(1003);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getInfPosicionarMouse(),(1004);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getCnpjCPFUnico(),(1005);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getImpCodPersonalizado(),(1006);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getLogListRelImp(),(1007);\n\t\t// Assert.assertEquals(result.getConfigGeralList().get(0).getObsProdFinProd(),(1008);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigGeral(id, TabelaEnum.CONFIGGERAL, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configGeral\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configGeral/delete/\", entitys,\n\t\t\t\tConfigGeralResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigGeralList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void listAllMedico() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new MedicoInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tMedicoResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/medico/fetchPage/\", entitys,\n\t\t\t\tMedicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getMedicoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertMedico(id, TabelaEnum.MEDICO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"medico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/medico/insert/\", entitys,\n\t\t\t\tMedicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertMedico(id, TabelaEnum.MEDICO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"medico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/medico/update/\", entitys,\n\t\t\t\tMedicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tMedicoInquiryRequest request001 = new MedicoInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/medico/fetchPage/\", entitys,\n\t\t\t\tMedicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getMedicoList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getMedicoList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getMedicoList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getMedicoList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getMedicoList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getMedicoList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertMedico(id, TabelaEnum.MEDICO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"medico\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/medico/delete/\", entitys,\n\t\t\t\tMedicoResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getMedicoList().size(), count.intValue());\n\n\t}", "@Test\r\n\tpublic void getCompanyNameTest() throws Exception {\r\n\t\tString comapanyName = \"ABC\";\r\n\t\tString uriString = \"http://localhost:8080/sample/url\";\r\n\t\tURI uri = new URI(uriString);\r\n\t\tString json = \"{\\\"query\\\":{\\\"count\\\":1,\\\"created\\\":\\\"2016-11-23T09:55:57Z\\\",\\\"lang\\\":\\\"en-US\\\",\\\"results\\\":{\\\"quote\\\":{\\\"Name\\\":\\\"ABC Corp!\\\"}}}}\";\r\n\t\tString expected = \"ABC Corp!\";\r\n\r\n\t\tPowerMockito.whenNew(RestTemplate.class).withNoArguments().thenReturn(restTemplate);\r\n\t\tPowerMockito.doReturn(json).when(restTemplate).getForObject(uri, String.class);\r\n\t\tMockito.when(uriGeneratorService.getStockRestURI(comapanyName)).thenReturn(uri);\r\n\t\tString actual = companyDetailsServiceImpl.getCompanyName(comapanyName);\r\n\r\n\t\tAssert.assertEquals(expected, actual);\r\n\t}", "@Test\n\tpublic void listAllPaciente() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PacienteInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tPacienteResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/paciente/fetchPage/\",\n\t\t\t\tentitys, PacienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getPacienteList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertPaciente(id, TabelaEnum.PACIENTE, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"paciente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/paciente/insert/\", entitys,\n\t\t\t\tPacienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertPaciente(id, TabelaEnum.PACIENTE, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"paciente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/paciente/update/\", entitys,\n\t\t\t\tPacienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPacienteInquiryRequest request001 = new PacienteInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/paciente/fetchPage/\", entitys,\n\t\t\t\tPacienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getPacienteList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getPacienteList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getPacienteList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getPacienteList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getPacienteList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getPacienteList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper\n\t\t\t\t.writeValueAsString(Objects.insertPaciente(id, TabelaEnum.PACIENTE, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"paciente\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/paciente/delete/\", entitys,\n\t\t\t\tPacienteResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getPacienteList().size(), count.intValue());\n\n\t}", "@Test\n\tpublic void listAllConfigAlertas() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigAlertasResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configAlertas/fetchPage/\", entitys, ConfigAlertasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigAlertasList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigAlertas(id, TabelaEnum.CONFIGALERTAS, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configAlertas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configAlertas/insert/\", entitys,\n\t\t\t\tConfigAlertasResponse.class);\n\t\t// Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigAlertas(id, TabelaEnum.CONFIGALERTAS, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configAlertas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configAlertas/update/\", entitys,\n\t\t\t\tConfigAlertasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configAlertas/fetchPage/\", entitys,\n\t\t\t\tConfigAlertasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigAlertasList().size(), 1);\n\n\t\t/// Assert.assertEquals(result.getConfigAlertasList().get(0).getEstoqMin(),(1001);\n\t\t// Assert.assertEquals(result.getConfigAlertasList().get(0).getEstoqMax(),(1002);\n\t\t// Assert.assertEquals(result.getConfigAlertasList().get(0).getErroNFe(),(1003);\n\t\t// Assert.assertEquals(result.getConfigAlertasList().get(0).getPdCompra(),(1004);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigAlertas(id, TabelaEnum.CONFIGALERTAS, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configAlertas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configAlertas/delete/\", entitys,\n\t\t\t\tConfigAlertasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigAlertasList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void listAllConfigVendas() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigVendasResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configVendas/fetchPage/\", entitys, ConfigVendasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigVendasList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigVendas(id, TabelaEnum.CONFIGVENDAS, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configVendas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configVendas/insert/\", entitys,\n\t\t\t\tConfigVendasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigVendas(id, TabelaEnum.CONFIGVENDAS, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configVendas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configVendas/update/\", entitys,\n\t\t\t\tConfigVendasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configVendas/fetchPage/\", entitys,\n\t\t\t\tConfigVendasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getConfigVendasList().size(), 15);\n\n\t\t//\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getDescontoMaxVenda(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getObservacao(),\"\"observacao_2\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getImprSegVia(),(1003);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getImprAssinatura(),(1004);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getImprResumoFinanc(),(1005);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getAtuaPrecoClonar(),(1006);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getImprColUnidade(),(1007);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getBloquearvendProdSemEstoq(),(1008);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getAddDespCalcImposto(),(1009);\n\t\t// Assert.assertEquals(result.getConfigVendasList().get(0).getRetSubstTribICMS(),(1010);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigVendas(id, TabelaEnum.CONFIGVENDAS, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configVendas\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configVendas/delete/\", entitys,\n\t\t\t\tConfigVendasResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigVendasList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void listAllConfigFiscal() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigFiscalResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configFiscal/fetchPage/\", entitys, ConfigFiscalResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigFiscalList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigFiscal(id, TabelaEnum.CONFIGFISCAL, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configFiscal\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configFiscal/insert/\", entitys,\n\t\t\t\tConfigFiscalResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigFiscal(id, TabelaEnum.CONFIGFISCAL, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configFiscal\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configFiscal/update/\", entitys,\n\t\t\t\tConfigFiscalResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configFiscal/fetchPage/\", entitys,\n\t\t\t\tConfigFiscalResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getConfigFiscalList().size(), 20);\n\n\t\t// Assert.assertEquals(result.getConfigFiscalList().get(0).getPrincAtividade(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigFiscalList().get(0).getRegime(),(new\n\t\t// Regime());\n\t\t// Assert.assertEquals(result.getConfigFiscalList().get(0).getAliqSimples(),(10.00);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigFiscal(id, TabelaEnum.CONFIGFISCAL, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configFiscal\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configFiscal/delete/\", entitys,\n\t\t\t\tConfigFiscalResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigFiscalList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void listAllConfigProduto() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigProdutoResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configProduto/fetchPage/\", entitys, ConfigProdutoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigProdutoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigProduto(id, TabelaEnum.CONFIGPRODUTO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configProduto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configProduto/insert/\", entitys,\n\t\t\t\tConfigProdutoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigProduto(id, TabelaEnum.CONFIGPRODUTO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configProduto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configProduto/update/\", entitys,\n\t\t\t\tConfigProdutoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configProduto/fetchPage/\", entitys,\n\t\t\t\tConfigProdutoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getConfigProdutoList().size(), 1);\n\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCfop(),(new\n\t\t// Cfop());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsSitTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsOrigem(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsModalidadeBC(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsRedBaseCalc(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsAliq(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsMotDesoneracao(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsModBCST(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsMargValAdic(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsRedBaseCalcST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsPrecoUnitPautaST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIcmsAliqST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiSitTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiClasCigarroBebida(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiCNPJProd(),\"\"ipiCNPJProd_15\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiCodSeloCont(),\"\"ipiCodSeloCont_16\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiQtdSelo(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiCodEnquad(),(1018);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiTipCalc(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getIpiAliq(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPisSitTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPisAliq(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPisValUnidtrib(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPistipoCalcSubstTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPisAliqST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getPisValorAliqST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsSubstTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsAliq(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsValorAliq(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsTipoCalcSubstTrib(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsAliqST(),(10.00);\n\t\t// Assert.assertEquals(result.getConfigProdutoList().get(0).getCofinsValorAliqST(),(10.00);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigProduto(id, TabelaEnum.CONFIGPRODUTO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configProduto\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configProduto/delete/\", entitys,\n\t\t\t\tConfigProdutoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tAssert.assertEquals(result.getConfigProdutoList().size(), count.intValue());\n\n\t}", "@Test\n\tpublic void listAllConfigCarne() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigCarneResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configCarne/fetchPage/\", entitys, ConfigCarneResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigCarneList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigCarne(id, TabelaEnum.CONFIGCARNE, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configCarne\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configCarne/insert/\", entitys,\n\t\t\t\tConfigCarneResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigCarne(id, TabelaEnum.CONFIGCARNE, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configCarne\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configCarne/update/\", entitys,\n\t\t\t\tConfigCarneResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configCarne/fetchPage/\", entitys,\n\t\t\t\tConfigCarneResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigCarneList().size(), 20);\n\n\t\t// Assert.assertEquals(result.getConfigCarneList().get(0).getCarneBotelo(),(1001);\n\t\t// Assert.assertEquals(result.getConfigCarneList().get(0).getCarneNormal(),(1002);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigCarne(id, TabelaEnum.CONFIGCARNE, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configCarne\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configCarne/delete/\", entitys,\n\t\t\t\tConfigCarneResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigCarneList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n public void bodyContainsCurrentUserUrl() {\n ResponseEntity<User> response = restTemplate.getForEntity(BASE_URL + \"/users/YanCanCode\", User.class);\n\n // Assert\n assertEquals(\"YanCanCode\", response.getBody().getLogin());\n }", "@Test\n\tpublic void listAllFuncionario() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new FuncionarioInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tFuncionarioResponse result = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/funcionario/fetchPage/\",\n\t\t\t\tentitys, FuncionarioResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getFuncionarioList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertFuncionario(id, TabelaEnum.FUNCIONARIO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"funcionario\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/funcionario/insert/\", entitys,\n\t\t\t\tFuncionarioResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertFuncionario(id, TabelaEnum.FUNCIONARIO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"funcionario\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/funcionario/update/\", entitys,\n\t\t\t\tFuncionarioResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tFuncionarioInquiryRequest request001 = new FuncionarioInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/funcionario/fetchPage/\", entitys,\n\t\t\t\tFuncionarioResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getFuncionarioList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getFuncionarioList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFuncionarioList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFuncionarioList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFuncionarioList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getFuncionarioList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertFuncionario(id, TabelaEnum.FUNCIONARIO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"funcionario\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/funcionario/delete/\", entitys,\n\t\t\t\tFuncionarioResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getFuncionarioList().size(), count.intValue());\n\n\t}", "@Test\n\tpublic void listAllTransportador() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:pessoa/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new TransportadorInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tTransportadorResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"pessoa/api/transportador/fetchPage/\", entitys, TransportadorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getTransportadorList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertTransportador(id, TabelaEnum.TRANSPORTADOR, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"transportador\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/transportador/insert/\", entitys,\n\t\t\t\tTransportadorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertTransportador(id, TabelaEnum.TRANSPORTADOR, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"transportador\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/transportador/update/\", entitys,\n\t\t\t\tTransportadorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tTransportadorInquiryRequest request001 = new TransportadorInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/transportador/fetchPage/\", entitys,\n\t\t\t\tTransportadorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getTransportadorList().size(), 1);\n\n\t\t//Assert.assertEquals(result.getTransportadorList().get(0).getNome(), \"nome_1 - UPDATE\");\n\t\t//Assert.assertEquals(result.getTransportadorList().get(0).getNomePai(), \"nomePai_2 - UPDATE\");\n\t\t//Assert.assertEquals(result.getTransportadorList().get(0).getNomeMae(), \"nomeMae_3 - UPDATE\");\n\t\t//Assert.assertEquals(result.getTransportadorList().get(0).getNomeConjugue(), \"nomeConjugue_4 - UPDATE\");\n\t\t//Assert.assertEquals(result.getTransportadorList().get(0).getFoto(), \"foto_8 - UPDATE\");\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertTransportador(id, TabelaEnum.TRANSPORTADOR, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"transportador\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"pessoa/api/transportador/delete/\", entitys,\n\t\t\t\tTransportadorResponse.class);\n\t\t//Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t//Assert.assertEquals(result.getTransportadorList().size(), count.intValue());\n\n\t}", "public <T> T getForObject(URI url, Class<T> responseType) throws RestClientException {\n return restTemplate.getForObject(url, responseType);\n }", "@Test\n\tpublic void listAllConfigEntrada() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfigEntradaResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configEntrada/fetchPage/\", entitys, ConfigEntradaResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfigEntradaList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigEntrada(id, TabelaEnum.CONFIGENTRADA, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configEntrada\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configEntrada/insert/\", entitys,\n\t\t\t\tConfigEntradaResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigEntrada(id, TabelaEnum.CONFIGENTRADA, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configEntrada\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configEntrada/update/\", entitys,\n\t\t\t\tConfigEntradaResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configEntrada/fetchPage/\", entitys,\n\t\t\t\tConfigEntradaResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigEntradaList().size(), 20);\n\n\t\t// Assert.assertEquals(result.getConfigEntradaList().get(0).getValorTotalFixo(),(1001);\n\t\t// Assert.assertEquals(result.getConfigEntradaList().get(0).getManterPrecoVendaProd(),(1002);\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfigEntrada(id, TabelaEnum.CONFIGENTRADA, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configEntrada\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configEntrada/delete/\", entitys,\n\t\t\t\tConfigEntradaResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfigEntradaList().size(),\n\t\t// count.intValue());\n\n\t}", "@Test\n\tpublic void testGetAllPatients() {\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\tHttpEntity<String> entity = new HttpEntity<String>(null, headers);\n\t\tResponseEntity<String> response = restTemplate.exchange(getRootUrl() + \"/homepage\",HttpMethod.GET, entity, String.class);\n\t\tassertEquals(200, response.getStatusCodeValue());\n\t}", "@Test\n\tpublic void listAllConfiguracaoNFe() throws KeyManagementException, UnrecoverableKeyException, KeyStoreException,\n\t\t\tNoSuchAlgorithmException, CertificateException, Exception {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfiguracaoNFeResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configuracaoNFe/fetchPage/\", entitys,\n\t\t\t\tConfiguracaoNFeResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfiguracaoNFeList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracaoNFe(id, TabelaEnum.CONFIGURACAONFE, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configuracaoNFe\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracaoNFe/insert/\", entitys,\n\t\t\t\tConfiguracaoNFeResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracaoNFe(id, TabelaEnum.CONFIGURACAONFE, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configuracaoNFe\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracaoNFe/update/\", entitys,\n\t\t\t\tConfiguracaoNFeResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracaoNFe/fetchPage/\", entitys,\n\t\t\t\tConfiguracaoNFeResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().size(), 20);\n\n\t\t// NFeConfigTeste config = new NFeConfigTeste();\n\t\t// NFStatusServicoConsultaRetorno retorno = new\n\t\t// WSFacade(config).consultaStatus(NFUnidadeFederativa.MG,\n\t\t// NFModelo.NFE);\n\t\t// System.out.println(retorno.getStatus());\n\t\t// System.out.println(retorno.getMotivo());\n\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getPresCompr(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getDestConsFinal(),(1002);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getPreencherDataHora(),(1003);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getIcmsPadrao(),(10.00);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getIpiPadrao(),(10.00);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getPisPadrao(),(10.00);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getCofinsPadrao(),(10.00);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getAmbienteEnvio(),(new\n\t\t// DoisValores());\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getServMsmNota(),(10.00);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getSerieEnvio(),\"\"serieEnvio_10\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getAnexarXmlEmail(),(1011);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getIdCSC(),\"\"idCSC_12\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getCSC(),\"\"cSC_13\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getInformacaoAdd(),\"\"informacaoAdd_14\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getCertificado(),\"\"certificado_15\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getSenha(),\"\"senha_16\"\n\t\t// - UPDATE\");\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getSalvarSenha(),(1017);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getCfopPadrao(),(new\n\t\t// Cfop());\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().get(0).getConfSMTP(),(new\n\t\t// ConfigSMTP());\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracaoNFe(id, TabelaEnum.CONFIGURACAONFE, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configuracaoNFe\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracaoNFe/delete/\", entitys,\n\t\t\t\tConfiguracaoNFeResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfiguracaoNFeList().size(),\n\t\t// count.intValue());\n\n\t}", "public String getRest(String uri) {\n WebResource.Builder builder = getClientBuilder(uri);\n ClientResponse response = builder.get(ClientResponse.class);\n\n if (response.getStatus() != HTTP_OK) {\n log.info(\"REST GET request returned error code {}\",\n response.getStatus());\n }\n return response.getEntity(String.class);\n }", "@Test\n\tpublic void listAllConfiguracao() throws JsonParseException, JsonMappingException, IOException {\n\n\t\tInteger count = 0;\n\t\tInteger id = 10000;\n\t\tRestTemplate restTemplate = new RestTemplate();\n\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"username\", \"[email protected]\");\n\n\t\tMap<String, String> params = new HashMap<String, String>();\n\t\tparams.put(\"username\", \"[email protected]\");\n\t\tparams.put(\"password\", \"[email protected]\");\n\n\t\tRestTemplate rest = new RestTemplate();\n\t\trest.setMessageConverters(Arrays.asList(new StringHttpMessageConverter(), new FormHttpMessageConverter()));\n\t\tMultiValueMap<String, String> paramss = new LinkedMultiValueMap<String, String>();\n\t\tparamss.set(\"username\", \"[email protected]\");\n\t\tparamss.set(\"password\", \"devil\");\n\t\tURI tgtUrl = rest.postForLocation(REST_SERVICE_URI + \"auth/api/authenticate\", paramss, Collections.emptyMap());\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tSystem.out.println(\"[\" + tgtUrl + \"]\");\n\n\t\tResponseEntity<String> st = rest.postForEntity(REST_SERVICE_URI + \"auth/api/authenticate\", paramss,\n\t\t\t\tString.class);\n\t\tSystem.out.println(\"[\" + st.getBody() + \"]\");\n\t\tSystem.out.println(\"[\" + st + \"]\");\n\t\tString tk = st.getBody();\n\t\tClass<? extends String> mt = tk.getClass();\n\t\tSystem.out.println(\"[\" + mt + \"]\");\n\t\tObjectMapper mapper = new ObjectMapper();\n\t\tModelToken obj = mapper.readValue(st.getBody(), ModelToken.class);\n\n\t\tSystem.out.println(\"[\" + obj.getToken() + \"]\");\n\n\t\theaders = new HttpHeaders();\n\t\theaders.set(\"Header\", \"value\");\n\t\theaders.setContentType(MediaType.APPLICATION_JSON);\n\t\theaders.set(\"Other-Header\", \"othervalue\");\n\t\theaders.set(\"X-Auth-Token\", obj.getToken());\n\t\tString a = \"request:{pageSize: 20, startPage: 2, sortExpressions: null, preQueryCount: true, maxPreQueryCount: 0}, token:[email protected]:1469815365580:33f9281620d9dc7df079e056ad235420, url:configuracao/api/cfop/fetchPage/\";\n\t\tHttpEntity<String> entity = new HttpEntity<String>(\"{}\", headers);\n\n\t\t// =========== fetch\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchALL==============================================\");\n\t\tString jsonInString = mapper.writeValueAsString(new PagedInquiryRequest());\n\t\tSystem.out.println(jsonInString);\n\t\tHttpEntity<String> entitys = new HttpEntity<String>(jsonInString, headers);\n\t\tConfiguracaoResponse result = restTemplate.postForObject(\n\t\t\t\tREST_SERVICE_URI + \"configuracao/api/configuracao/fetchPage/\", entitys, ConfiguracaoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\tcount = result.getConfiguracaoList().size();\n\n\t\t// =========== Insert\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================INSERT==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracao(id, TabelaEnum.CONFIGURACAO, PersistenceActionEnum.INSERT));\n\t\tSystem.out.println(jsonInString);\n\t\tString requestJson = \"{\\\"configuracao\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracao/insert/\", entitys,\n\t\t\t\tConfiguracaoResponse.class);\n\t\t// Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== Update\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================UPDATE==============================================\");\n\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracao(id, TabelaEnum.CONFIGURACAO, PersistenceActionEnum.UPDATE));\n\t\trequestJson = \"{\\\"configuracao\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracao/update/\", entitys,\n\t\t\t\tConfiguracaoResponse.class);\n\t\t// Assert.assertEquals(result.isOperationSuccess(), true);\n\n\t\t// =========== FetchbyID\n\t\t// ================================================================\n\t\tSystem.out.println(\"==================================FetchID==============================================\");\n\n\t\tPagedInquiryRequest request001 = new PagedInquiryRequest();\n\t\trequest001.setId(id);\n\t\tjsonInString = mapper.writeValueAsString(request001);\n\t\tSystem.out.println(jsonInString);\n\t\tentitys = new HttpEntity<String>(jsonInString, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracao/fetchPage/\", entitys,\n\t\t\t\tConfiguracaoResponse.class);\n\t\t// Assert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfiguracaoList().size(), 1);\n\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfGeral(),(new\n\t\t// ConfigGeral());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfNFe(),(new\n\t\t// ConfiguracaoNFe());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfFiscal(),(new\n\t\t// ConfigFiscal());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfProd(),(new\n\t\t// ConfigProduto());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfVendas(),(new\n\t\t// ConfigVendas());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfCMTP(),(new\n\t\t// ConfigSMTP());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfEntrada(),(new\n\t\t// ConfigEntrada());\n\t\t// Assert.assertEquals(result.getConfiguracaoList().get(0).getConfCarne(),(new\n\t\t// ConfigCarne());\n\n\t\t// =======================\n\t\tSystem.out.println(\"==================================DELETE==============================================\");\n\t\tjsonInString = mapper.writeValueAsString(\n\t\t\t\tObjects.insertConfiguracao(id, TabelaEnum.CONFIGURACAO, PersistenceActionEnum.DELETE));\n\t\trequestJson = \"{\\\"configuracao\\\":\" + jsonInString + \"}\";\n\t\tentitys = new HttpEntity<String>(requestJson, headers);\n\t\tresult = restTemplate.postForObject(REST_SERVICE_URI + \"configuracao/api/configuracao/delete/\", entitys,\n\t\t\t\tConfiguracaoResponse.class);\n\t\tAssert.assertEquals(result.isOperationSuccess(), true);\n\t\t// Assert.assertEquals(result.getConfiguracaoList().size(),\n\t\t// count.intValue());\n\n\t}", "@Bean\n public RestTemplate restTemplate()\n throws KeyStoreException, NoSuchAlgorithmException, KeyManagementException {\n // use the TrustSelfSignedStrategy to allow Self Signed Certificates\n SSLContext sslContext = SSLContextBuilder\n .create()\n .loadTrustMaterial(new TrustSelfSignedStrategy())\n .build();\n\n HostnameVerifier allowAllHosts = new NoopHostnameVerifier();\n SSLConnectionSocketFactory connectionFactory = new SSLConnectionSocketFactory(sslContext, allowAllHosts);\n CloseableHttpClient client = HttpClients\n .custom()\n .setSSLSocketFactory(connectionFactory)\n .build();\n HttpComponentsClientHttpRequestFactory requestFactory = new HttpComponentsClientHttpRequestFactory();\n requestFactory.setHttpClient(client);\n\n return new RestTemplate(requestFactory);\n }", "@Test\n public void shouldRetrieveAPaymentViaGet() throws Exception {\n ResponseEntity<String> response = postTestPaymentAndGetResponse();\n String location = getLocationHeader(response);\n\n //when: the payment is fetched via get:\n ResponseEntity<Payment> getResponse = restTemplate.getForEntity(location, Payment.class);\n //then: the response status code should be OK:\n assertEquals(HttpStatus.OK, getResponse.getStatusCode());\n //and: the data on the response should be correct, e.g. check the orgainsation_id field:\n Payment payment = getResponse.getBody();\n assertEquals(testPaymentAsObject.getOrganisationId(), payment.getOrganisationId());\n }", "@Test\n public void findById() {\n System.out.println(\"\\n--- Singer by id=1 ---\");\n\n Singer singer = restTemplate.getForObject(\n \"http://localhost:9082/restful-ws/singer/{id}\", Singer.class, 1);\n\n System.out.println(singer);\n }", "java.lang.String getResponse();", "private <T> ResponseEntity<T> executeRequest(String url, HttpMethod method, HttpEntity<?> reqEntity,\n\t\t\tClass<T> responseType) {\n\t\ttry {\n\t\t\treturn restTemplate.exchange(url, method, reqEntity, responseType);\n\n\t\t} catch (final HttpClientErrorException | HttpServerErrorException e) {\n\t\t\tthrow new MicroserviceException(\n\t\t\t\t\t\"HttpResponse code : \" + e.getStatusCode() + \" , cause: \" + e.getResponseBodyAsString());\n\t\t}\n\n\t}", "@Override\n\tpublic RestTemplate getRestTemplate(String ip, int port) {\n\t\tSimpleClientHttpRequestFactory factory = new SimpleClientHttpRequestFactory();\n\t\tInetSocketAddress address = new InetSocketAddress(ip, port);\n\t\tProxy proxy = new Proxy(Proxy.Type.HTTP, address);\n\n\t\tfactory.setProxy(proxy);\n\n\t\treturn new RestTemplate(factory);\n\t}", "@Test\n public void crudFunctionality() throws Exception {\n AdventureMessage msg = new AdventureMessage();\n msg.setMessage(\"TEST MESSAGE DELETE ME\");\n msg.setRarity(10);\n HashMap responseCreate = this.restTemplate.postForObject(\"http://localhost:\" + port + \"/adventure-message/save\",\n msg,\n HashMap.class);\n // do assertions\n assertTrue(\"response contains body key\", responseCreate.containsKey(\"status\"));\n assertTrue(\"response contains status key\", responseCreate.containsKey(\"body\"));\n\n // todo post\n HashMap responseFind = this.restTemplate.postForObject(\"http://localhost:\" + port + \"/adventure-message/FindByMessageFuzzy\",\n new HashMap<String, String>() {{ put(\"message\", \"TEST MESSAGE DELETE ME\"); }},\n HashMap.class);\n // do assertions\n assertTrue(\"response contains body key\", responseCreate.containsKey(\"status\"));\n assertTrue(\"response contains status key\", responseCreate.containsKey(\"body\"));\n\n // todo grab the msg id\n System.out.println(\"what does this body look like?\" + responseFind.get(\"body\"));\n//\n// // todo delete\n// HashMap responseDelete = this.restTemplate.getForObject(\"http://localhost:\" + port + \"/adventure-message/delete/\" + \"<id>\",\n// HashMap.class);\n// // do assertions\n// assertTrue(\"response contains body key\", responseCreate.containsKey(\"status\"));\n// assertTrue(\"response contains status key\", responseCreate.containsKey(\"body\"));\n\n }", "@Test\n public void shouldGiveNotFoundResponseCodeIfTryToRetrieveUnknownPayment() throws Exception {\n ResponseEntity<Payment> response = restTemplate.getForEntity(\"/payments/unKnownId\", Payment.class);\n //then: the response code should be 'not found'\n assertEquals(HttpStatus.NOT_FOUND, response.getStatusCode());\n }", "@Nullable\n <T> T getForObject(URI url, Class<T> responseType) throws RestClientException;", "@Override\n\tpublic Recipe getRecipe(int id) {\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\t\n\t\tResponseEntity<Recipe> rateResponse =\n\t\t restTemplate.exchange(BASE_URL + RECIPE_URL + id, HttpMethod.GET, \n\t\t \t\tnull, new ParameterizedTypeReference<Recipe>() {\n\t\t });\n\t\tRecipe recipe = rateResponse.getBody();\n\t\tlogger.debug(\"RECIPE Info :\" + recipe);\n\t\treturn recipe;\n\t}", "public Response getRequestForGetAPI(String endpoint) {\n response = given().contentType(ContentType.JSON)\n .when()\n .get(endpoint)\n .then()\n .extract().response();\n\n System.out.println(\"Response of API :\"+response.getBody().asString());\n\n String body = response.getBody().asString();\n JSONArray responseArray= new JSONArray(body);\n comment.setBody(responseArray);\n return response;\n\n }", "@HystrixCommand(/*commandProperties = {\n @HystrixProperty(name = \"execution.isolation.strategy\", value = \"SEMAPHORE\"),\n @HystrixProperty(name = \"execution.isolation.thread.timeoutInMilliseconds\", value = \"90000\") },*/\n fallbackMethod = \"getTwitterDataJsonFallback\")\n public ImportTwitterResponse getTwitterDataJson(ImportTwitterRequest importRequest) throws ImporterException {\n\n /*HttpHeaders requestHeaders = new HttpHeaders();\n requestHeaders.setContentType(MediaType.APPLICATION_JSON);\n\n HttpEntity<ImportTwitterRequest> requestEntity =new HttpEntity<>(importRequest,requestHeaders);\n\n ResponseEntity<ImportTwitterResponse> responseEntity = restTemplate.exchange(\"http://Import-Service/Import/getTwitterDataJson\", HttpMethod.POST,null, ImportTwitterResponse.class);\n ImportTwitterResponse importResponse = new ImportTwitterResponse(\"hello world\"); // responseEntity.getBody();\n\n return importResponse;*/\n\n\n HttpHeaders requestHeaders = new HttpHeaders();\n requestHeaders.setContentType(MediaType.APPLICATION_JSON);\n\n ObjectMapper mapper = new ObjectMapper();\n mapper.configure(SerializationFeature.WRAP_ROOT_VALUE, false); //root name of class, same root value of json\n mapper.configure(SerializationFeature.EAGER_SERIALIZER_FETCH, true);\n\n HttpEntity<String> request = null;\n try {\n request = new HttpEntity<>(mapper.writeValueAsString(importRequest),requestHeaders);\n } catch (JsonProcessingException e) {\n e.printStackTrace();\n }\n //ImportTwitterResponse importResponse = restTemplate.postForObject(\"http://Import-Service/Import/getTwitterDataJson\", request, ImportTwitterResponse.class);\n\n ResponseEntity<?> importResponse = null;\n //importResponse = restTemplate.exchange(\"http://Import-Service/Import/getTwitterDataJson\",HttpMethod.POST,request,new ParameterizedTypeReference<ServiceErrorResponse>() {});\n\n if (importResponse != null && importResponse.getBody().getClass() == ServiceErrorResponse.class) {\n ServiceErrorResponse serviceErrorResponse = (ServiceErrorResponse) importResponse.getBody();\n if (serviceErrorResponse.getErrors() != null) {\n String errors = serviceErrorResponse.getErrors().get(0);\n for (int i = 1; i < serviceErrorResponse.getErrors().size(); i++) {\n errors = \"; \" + errors;\n }\n\n throw new ImporterException(errors);\n }\n }\n\n importResponse = restTemplate.exchange(\"http://Import-Service/Import/getTwitterDataJson\",HttpMethod.POST,request,new ParameterizedTypeReference<ImportTwitterResponse>() {});\n return (ImportTwitterResponse) importResponse.getBody();\n }", "@Bean public RestTemplate createRestTemplate() {\n RestTemplate restTemplate = new RestTemplate();\n List<HttpMessageConverter<?>> converters = new ArrayList<>();\n MappingJackson2HttpMessageConverter jsonConverter = new MappingJackson2HttpMessageConverter();\n jsonConverter.setObjectMapper(objectMapper);\n converters.add(jsonConverter);\n restTemplate.setMessageConverters(converters);\n\n return restTemplate;\n }", "public <T> T getForObject(String url, Class<T> responseType, Object... uriVariables) throws RestClientException {\n return restTemplate.getForObject(url, responseType, uriVariables);\n }", "@Bean\n @ConditionalOnMissingBean\n public RestTemplate restTemplate() {\n return new RestTemplate();\n }", "@Rest(converters = { MappingJackson2HttpMessageConverter.class, StringHttpMessageConverter.class })\npublic interface MyRestClient {\n\n @Post(\"http://api.weixin.qq.com/cgi-bin/token?grant_type=client_credential&appid=wx9c61ca4d88538922&secret=f3aac1609d3a0ced1ff6d54f5157f740\")\n Err getErr();\n\n}", "@RequestMapping(path=\"/initPaymentGet\", method = RequestMethod.GET)//, produces = MediaType.APPLICATION_JSON_VALUE, consumes = MediaType.APPLICATION_JSON_VALUE)\n\tpublic ResponseEntity<Object> test() {\n\t\tlogger.info(\"Init payment\");\n\t\t//System.out.println(\"DTO: \" + btcDTO.getPrice_currency());\n\t\tString pom = \"\";\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\t\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\theaders.add(\"Authorization\", \"ab7fzPdN49-xBVoY_LdSifCZiVrqCbdcfjWdweJS\");\n\t\tResponseEntity<String> responseEntity = new RestTemplate().exchange(CREATE_ORDER_API, HttpMethod.GET,\n\t\t\t\tnew HttpEntity<String>(pom, headers), String.class);\n\n\t\t//restTemplate.getForEntity(\"https://google.rs\", String.class);\n\t\t//ResponseEntity<String> response = restTemplate.getForEntity(\"https://api-sandbox.coingate.com/v2/orders\", String.class);\n\t\t//ResponseEntity<String> response = restTemplate.postForEntity(\"https://api.coingate.com/v2/orders\", btcDTO, String.class);\n\t\t\n\t\treturn new ResponseEntity<Object>(responseEntity,HttpStatus.OK);\n\t}", "@Override\n\tpublic List<Recipe> getAllRecipe() {\n\t\tRestTemplate restTemplate = new RestTemplate();\n\t\t\n\t\tResponseEntity<List<Recipe>> rateResponse =\n\t\t restTemplate.exchange(BASE_URL + RECIPE_URL, HttpMethod.GET, \n\t\t \t\tnull, new ParameterizedTypeReference<List<Recipe>>() {\n\t\t });\n\t\tList<Recipe> recipeList = rateResponse.getBody();\n\t\tlogger.debug(\"RECIPE Info :\" + recipeList);\n\t\treturn recipeList;\n\t}", "@Test\r\n\tpublic void createDirectTargetGroupsWithObject_V1_getResponseEntity()\tthrows ClientProtocolException, IOException, JSONException {\r\n\t\t\t\t\r\n\t\t/**\r\n\t\t * Create a direct target group with fake data\r\n\t\t */\r\n\t\t\r\n\t\tDirectTargetGroup directTargetGroupSent,directTargetGroupReceived,directTargetGroupFound;\r\n\t\tResponseEntity<String> responseCreate,responseGet, responseDelete;\r\n\t\t\r\n\t\t\r\n\t\tdirectTargetGroupSent = FakeObjectsFactory.getDirectTargetGroupEntity(new DirectTargetGroup());\r\n\t\tHttpEntity<DirectTargetGroup> request = new HttpEntity<DirectTargetGroup>(directTargetGroupSent);\r\n \r\n\t\t/* CREATE: HTTP Methos POST (postForEntity)*/\r\n\t\turl.setParam(null);\r\n\t\t\r\n\t\tLOGGER.debug(\"URL:\"+url.get());\r\n\t\tresponseCreate = restTemplate.postForEntity(url.get(), request, String.class);\r\n\t\tdirectTargetGroupReceived = objectMapper.readValue(responseCreate.getBody(), DirectTargetGroup.class);\r\n\t\t\r\n\t\tassertEquals(directTargetGroupSent.getDescriptionEn(), directTargetGroupReceived.getDescriptionEn());\r\n\t\tassertEquals(directTargetGroupSent.getOrderNumber(), directTargetGroupReceived.getOrderNumber());\r\n\t\t\r\n\t\tString jsonString = objectMapper.writeValueAsString(directTargetGroupReceived);\r\n\t\t\r\n\t\tLOGGER.debug(\"URL:\"+url.get());\r\n\t\tLOGGER.debug(\"received:\"+jsonString);\r\n\t\t// LOGGER.debug(\"expected:\"+expectedResponse);\r\n\t\t\r\n\t\t\r\n\t\t/**\r\n\t\t * Read the direct target group created (getForEntity)\r\n\t\t */\r\n\t\t\r\n\t\turl.setMethod(\"/last\");\r\n\t\tresponseGet = restTemplate.getForEntity(url.get(), String.class);\r\n\t\tdirectTargetGroupFound = objectMapper.readValue(responseGet.getBody(), DirectTargetGroup.class);\r\n\t\t\r\n\t\turl.setMethod(null);\r\n\t\t\r\n\t\tassertEquals(directTargetGroupFound.getDescriptionEn(), directTargetGroupReceived.getDescriptionEn());\r\n\t\tassertEquals(directTargetGroupFound.getOrderNumber(), directTargetGroupReceived.getOrderNumber());\r\n\t\t\r\n\t\t/**\r\n\t\t * Delete the direct target group created (getForEntity)\r\n\t\t */\r\n\t\t\r\n\t\turl.setMethod(null);\r\n\t\turl.setParam(\"/{id}\");\r\n\t\t\r\n\t\tMap < String, String > params = new HashMap < String, String > ();\r\n\t params.put(\"id\", directTargetGroupReceived.getId().toString());\r\n\r\n\t restTemplate.delete(url.get(), params);\r\n\r\n\t}", "private String doHttpClientGet() {\n\t\t\r\n\t\tHttpGet httpGet=new HttpGet(url);\r\n\t\tHttpClient client=new DefaultHttpClient();\r\n\t\ttry {\r\n\t\t\tHttpResponse response=client.execute(httpGet);\r\n\t\t\tif(response.getStatusLine().getStatusCode()==HttpStatus.SC_OK){\r\n\t\t\t\tresult=EntityUtils.toString(response.getEntity());\t\r\n\t\t\t\t}\r\n\t\t\t\t\r\n\t\t\t\tSystem.out.println(\"content----->\"+result);\r\n\t\t} catch (ClientProtocolException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t} catch (IOException e) {\r\n\t\t\t// TODO Auto-generated catch block\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t\treturn result;\r\n\t}", "@GetMapping(\"/getRE\")\n\tpublic List<EnquiryDetails> getDataRE()\n\t{\n\t\tString url=\"http://localhost:8083/getclient/getalldatafor_re\";\n\t\tList<EnquiryDetails> list=rt.getForObject(url, List.class);\n\t\tSystem.out.println(list);\n\t\treturn list;\n\t}", "private String getEmployees() {\n\n String uri = new String(\"http://\" + mRESTServer.getHost() +\n mRESTServer.getContextPath());\n try {\n String result = restTemplate.getForObject(uri, String.class);\n\n System.out.println(result);\n return result+\": (\"+uri+\")\";\n\n } catch (HttpClientErrorException e) {\n /**\n *\n * If we get a HTTP Exception display the error message\n */\n log.error(\"error: \" + e.getResponseBodyAsString());\n\n ObjectMapper mapper = new ObjectMapper();\n ErrorHolder eh = null;\n try {\n eh = mapper.readValue(e.getResponseBodyAsString(), ErrorHolder.class);\n } catch (IOException ignored) {\n }\n\n log.error(\"error: \" + eh.getErrorMessage());\n\n } catch (Exception e) {\n log.error(\"error: \" + e.getMessage());\n\n }\n\n return null;\n }", "@Override\n @Bean\n public RestTemplate restTemplate(RestTemplateBuilder builder) {\n return builder.build();\n }", "public ResponseEntity<ResponseWrapper> prepareReponseEntity(String responseBody) {\n\t\tthis.mockServer\n\t\t.expect(requestTo(\"/display\"))\n\t\t.andExpect(method(HttpMethod.GET))\n\t\t.andRespond(\n\t\t\t\twithSuccess(responseBody, MediaType.APPLICATION_JSON));\n\t\t\n\t\tResponseEntity<ResponseWrapper> responseEntity=null;\n\t\ttry {\n\t\t\t\n\t\t\tResponseWrapper responseWrapper = restTemplate.getForObject(\n\t\t\t\t\t\"/display\", ResponseWrapper.class);\n\t\t\t\n\t\t\tresponseEntity = new ResponseEntity<ResponseWrapper>(\n\t\t\t\t\tresponseWrapper, HttpStatus.ACCEPTED);\n\t\t} catch (Exception e) {\n\t\t\t// TODO Auto-generated catch block\n\t\t\te.printStackTrace();\n\t\t}\n\t\treturn responseEntity;\n\t}", "String getResponse();", "protected <T> List<T> getForObject(String uri, ParameterizedTypeReference<List<T>> responseType) {\n return restTemplate.exchange(uri, HttpMethod.GET, null, responseType).getBody();\n }", "@Bean\n public RestTemplate restTemplate()\n throws KeyStoreException, NoSuchAlgorithmException, KeyManagementException {\n TrustStrategy acceptingTrustStrategy = (X509Certificate[] chain, String authType) -> true;\n\n SSLContext sslContext = org.apache.http.ssl.SSLContexts.custom()\n .loadTrustMaterial(null, acceptingTrustStrategy)\n .build();\n\n SSLConnectionSocketFactory csf = new SSLConnectionSocketFactory(sslContext);\n\n CloseableHttpClient httpClient = HttpClients.custom()\n .setSSLSocketFactory(csf)\n .build();\n\n HttpComponentsClientHttpRequestFactory requestFactory =\n new HttpComponentsClientHttpRequestFactory();\n\n requestFactory.setHttpClient(httpClient);\n RestTemplate restTemplate = new RestTemplate(requestFactory);\n\n return restTemplate;\n }", "public interface RestClientInt {\n\n /**\n * It performs a GET request\n * \n * @param client registration ID\n * \t\t\t (can be null\n * @param url\n * @param headers\n * (can be null)\n * @param queryParameters\n * (can be null)\n * @return\n */\n public ClientResponse performGetRequest(String clientRegistrationID, URL url, Map<String, String> headers, Map<String, String> queryParameters);\n\n /**\n * It returns the body representation of the HTTP response\n * \n * @param <T>\n * @param response\n * @param clazz\n * -> Class to use when parsing the response body\n * @return\n */\n public <T> T getBodyFromResponse(ClientResponse response, Class<T> clazz);\n\n}", "@Bean\n public RestTemplate restTemplate() throws KeyStoreException, NoSuchAlgorithmException, KeyManagementException {\n TrustStrategy acceptingTrustStrategy = (X509Certificate[] chain, String authType) -> true;\n\n SSLContext sslContext = org.apache.http.ssl.SSLContexts.custom()\n .loadTrustMaterial(null, acceptingTrustStrategy)\n .build();\n\n SSLConnectionSocketFactory csf = new SSLConnectionSocketFactory(sslContext);\n\n CloseableHttpClient httpClient = HttpClients.custom()\n .setSSLSocketFactory(csf)\n .build();\n\n HttpComponentsClientHttpRequestFactory requestFactory =\n new HttpComponentsClientHttpRequestFactory();\n\n requestFactory.setHttpClient(httpClient);\n RestTemplate restTemplate = new RestTemplate(requestFactory);\n restTemplate = contentTypeHelper(restTemplate);\n return restTemplate;\n }", "public <T> T getForObject(String url, Class<T> responseType, Map<String, ?> uriVariables) throws RestClientException {\n return restTemplate.getForObject(url, responseType, uriVariables);\n }", "@Test\n public void Task6() {\n Body body= given()\n .when()\n .get(\"https://jsonplaceholder.typicode.com/todos/2\")\n .then()\n .statusCode(200)\n .log().body()\n .extract().as(Body.class)\n \n\n ;\n System.out.println(\"body = \" + body);\n\n }", "@Test\n\tpublic void test_get_by_id_success(){\n\t\tResponseEntity<User> response = template.getForEntity(\n\t\t\t\tREST_SERVICE_URI + \"/20\" + ACCESS_TOKEN + token, User.class);\n\t\tUser user = response.getBody();\n\t\tassertThat(user.getEmail(), is(\"[email protected]\"));\n\t\tassertThat(response.getStatusCode(), is(HttpStatus.OK));\n\t\tvalidateCORSHttpHeaders(response.getHeaders());\n\t}", "@Nullable\n <T> T getForObject(String url, Class<T> responseType, Object... uriVariables)\n throws RestClientException;", "public static void main(String[] args) {\n\t\tRestTemplate restTemplate = new RestTemplate(); \r\n\t\t String url = \"http://www.omdbapi.com/?t=titanic&y=&plot=short&r=json\";\r\n\t\t //restTemplate.getMessageConverters().add(new MappingJacksonHttpMessageConverter());\r\n\t\t \r\n\t\t Pelicula peli = restTemplate.getForObject(url, Pelicula.class); \r\n\t\t \r\n\t\t \r\n\t\t System.out.println(peli.getDirector());\r\n\t}", "@Test\n public void testGetSingleRecipe() throws Exception {\n System.out.println(\"getSingleRecipeREST\");\n String recipe = \"slow cooker beef stew\";\n Recipe expResult = r1;\n Recipe result = get(\"/recipes/specific/\" + recipe).then()\n .assertThat()\n .statusCode(HttpStatus.OK_200.getStatusCode())\n .extract()\n .as(Recipe.class);\n assertEquals(expResult, result);\n \n }", "@Test\n\tpublic void testLogin() {\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\tHttpEntity<String> entity = new HttpEntity<String>(null, headers);\n\t\tResponseEntity<String> response = restTemplate.exchange(getRootUrl() + \"/login\",HttpMethod.GET, entity, String.class);\n\t\tassertEquals(200, response.getStatusCodeValue());\n\t}", "@GetMapping(\"/products\")\n\t@HystrixCommand(fallbackMethod = \"getFallBackAllProducts\")\n\tpublic Products getAllProducts(){\n\t\tList<Product> pList=restTemplate.getForObject(\"http://product-service/products\", List.class);\n\t\tProducts p=new Products();\n\t\tp.setProductList(pList);\n\t\treturn p;\n\t}", "@LoadBalanced\n\t @Bean\n\t public RestTemplate makeTemp(RestTemplateBuilder builder) {\n\t\t\n\t\t return builder.build();\n\t\t \n\t }", "public RestClientResponseBean consumeRestApi(String requestObj, String apiUrl, HttpMethod requestType, String authToken, Optional<Map> queryParameters, Optional<Integer> customReadTimeout, Optional<Map> headerInformation) throws Exception {\n RestTemplate restTemplate = new RestTemplate();\n HttpComponentsClientHttpRequestFactory requestFactory = new HttpComponentsClientHttpRequestFactory();\n if(null != customReadTimeout && customReadTimeout.isPresent())\n requestFactory.setReadTimeout(customReadTimeout.get().intValue());\n else\n requestFactory.setReadTimeout(MasterDataBean.getInstance().getRestReadTimeout());\n\n requestFactory.setConnectTimeout(MasterDataBean.getInstance().getRestConnectionTimeout());\n\n restTemplate.setRequestFactory(requestFactory);\n\n log.info(\"Rest client Connection timeout value : {}ms, and read time out value : {}ms.\",MasterDataBean.getInstance().getRestConnectionTimeout(),\n ((null != customReadTimeout && customReadTimeout.isPresent())?customReadTimeout.get():MasterDataBean.getInstance().getRestReadTimeout()));\n //log.info(\"Request object sent: \" + requestObj);\n\n HttpEntity<String> entity;\n if (null != requestObj)\n entity = new HttpEntity<String>(requestObj, getHttpHeader(authToken, true, headerInformation, false));\n else\n entity = new HttpEntity<String>(getHttpHeader(authToken, false, headerInformation, false));\n try {\n long startTime = System.currentTimeMillis();\n UriComponentsBuilder uriBuilder = UriComponentsBuilder.fromUriString(apiUrl);\n\n if(null != queryParameters && queryParameters.isPresent()) {\n Map queryParametersToSet = queryParameters.get();\n queryParametersToSet.forEach((k,v) ->{\n uriBuilder.queryParam(k.toString(),v.toString());\n });\n\n }\n\n ResponseEntity<String> response = restTemplate.exchange(uriBuilder.toUriString(), requestType, entity, String.class);\n log.info(\"Time taken to retrieve response from REST api: \" + (System.currentTimeMillis() - startTime) + \"ms.\");\n log.info(\"Rest client response code: {}\", response.getStatusCodeValue());\n return new RestClientResponseBean(response.getStatusCodeValue(),response.getBody());\n } catch(HttpStatusCodeException e ) {\n List<String> customHeader = e.getResponseHeaders().get(\"x-app-err-id\");\n String svcErrorMessageID = \"\";\n if (customHeader != null) {\n svcErrorMessageID = customHeader.get(0);\n }\n log.error(\"Error response from REST call: \" + svcErrorMessageID + \" :: \" + e.getResponseBodyAsString());\n return new RestClientResponseBean(e.getRawStatusCode(), e.getResponseBodyAsString());\n //throw e;\n } catch (Exception e) {\n e.printStackTrace();\n log.error(\"Exception while making a REST call: \" + e.getMessage());\n throw e;\n }\n\n }", "@Test\n\tpublic void testdeleteUser() {\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\tHttpEntity<String> entity = new HttpEntity<String>(null, headers);\n\t\tResponseEntity<String> response = restTemplate.exchange(getRootUrl() + \"/delete-user?id=4\",HttpMethod.GET, entity, String.class);\n\t\tassertEquals(200,response.getStatusCodeValue());\n\t}", "@Bean\r\n public RestTemplate restTemplate(RestTemplateBuilder builder) {\r\n return builder.build();\r\n }", "@Override\n\tpublic Health getHealthInfo(String id) {\n\t\t RestTemplate restTemplate = new RestTemplate();\n\t\t \n\t\t Health healthInfo = restTemplate.getForObject(BASE_URL + HEALTH_STATUS_URL, Health.class, id);\n\t\t logger.debug(\"Employee Info :\" + healthInfo);\n\t\treturn healthInfo;\n\t}", "@Headers({\n \"Accept: application/json\",\n \"User-Agent: Mozilla/5.0\"\n })\n @GET(\"/products/\")\n Call<List<Product>> listProduct();", "private Object callGetRESTCall(String methodName,\n Class returnClass,\n String urlTemplate,\n Object... params) throws PropertyServerException\n {\n try\n {\n RestTemplate restTemplate = new RestTemplate();\n\n return restTemplate.getForObject(urlTemplate, returnClass, params);\n }\n catch (Throwable error)\n {\n ConnectedAssetErrorCode errorCode = ConnectedAssetErrorCode.CLIENT_SIDE_REST_API_ERROR;\n String errorMessage = errorCode.getErrorMessageId() + errorCode.getFormattedErrorMessage(methodName,\n omasServerURL,\n error.getMessage());\n\n throw new PropertyServerException(errorCode.getHTTPErrorCode(),\n this.getClass().getName(),\n methodName,\n errorMessage,\n errorCode.getSystemAction(),\n errorCode.getUserAction(),\n error);\n }\n }", "@DisplayName(\"Spartan /api/hello Endpoint Test\")\n @Test\n public void TestHello(){\n Response response = get(\"http://3.95.214.153:8000/api/hello\");\n\n // get status code out of this Response object\n System.out.println(\"response.statusCode() = \" + response.statusCode());//200\n\n // assert the status code is 200\n assertThat(response.statusCode(),is(200));\n\n // how to pretty print entire \"response body\"\n // prettyPrint() -- print and return the body as String\n String responseBodyAsString = response.prettyPrint();//print the body as a String\n\n System.out.println(\"==========================\");\n\n // assertThat the body is Hello from Sparta\n assertThat(responseBodyAsString,is(\"Hello from Sparta\"));\n\n // get the header called ContentType from the response\n //three ways of getting content-Type header in restAssure\n System.out.println(\"response.getHeader(\\\"Content-Type\\\") = \" + response.getHeader(\"Content-Type\"));//text/plain;charset=UTF-8 as String\n System.out.println(\"response.getContentType() = \" + response.getContentType());//text/plain;charset=UTF-8 as String\n System.out.println(\"response.contentType() = \" + response.contentType());//returns text/plain;charset=UTF-8 as String\n System.out.println(\"response.header(\\\"Content-Type\\\") = \" + response.header(\"Content-Type\"));//text/plain;charset=UTF-8\n\n\n // assert That Content-Type is text/plain;charset=UTF-8\n assertThat(response.contentType() , is(\"text/plain;charset=UTF-8\") );\n // assert That Content-Type startWith text\n assertThat(response.contentType(),startsWith(\"text\"));\n\n\n // Easy way to work with Content-type without typing much\n // We can use \"ContentType Enum\" from RestAssured to easily get \"main\" part content-type\n // ContentType.TEXT -->> returns text/plain as Enum(Object) not as String\n // startWith accept a String object\n // so use toString method to convert ContentType.TEXT to String so we can use it startWith\n //response.contentType() ===returns you String\n assertThat(response.contentType(),startsWith(ContentType.TEXT.toString()));// /api/hello end point returns us ONLY plain text\n\n assertThat(response.contentType() , is( not(ContentType.JSON) ) );//since end point does not return us JSON we can assert that this endpoint does not return JSON\n\n\n\n }", "@Test\n\tpublic void testGetAllMedicines() {\n\t\tHttpHeaders headers = new HttpHeaders();\n\t\tHttpEntity<String> entity = new HttpEntity<String>(null, headers);\n\t\tResponseEntity<String> response = restTemplate.exchange(getRootUrl() + \"/show-medicines\",HttpMethod.GET, entity, String.class);\n\t\tassertEquals(200,response.getStatusCodeValue());\n\t}", "public String getBalance(String accountNo ,String bank) {\r\n\t ClientBuilder clientBuilder = ClientBuilder.newBuilder();\r\n\t String message = null;\r\n\t //creating empty Client\r\n\t Client client = clientBuilder.build(); \r\n\t WebTarget target = client.target(JERSEY_BASE_URI).path(\"/account\").path(\"/balance\").queryParam(\"bank\", bank);\r\n\t System.out.println(\"base uri \"+target.toString());\r\n\t Invocation.Builder invocationBuilder = target.request();\r\n\t invocationBuilder.header(\"accountNo\",accountNo);\r\n\t /*After creation of invocation Builder Object we need to pass header or cookie parameter values to it \r\n\t * There are Two parts of the request is there\r\n\t * 1)Address part or WebAddress(Url with query and path and matrix paramters available)\r\n\t * 2)Request Part\r\n\t * Again it was divided into two more parts \r\n\t * 1)Cokkie or Requesty Headers \r\n\t * 2)Request Body(Here you can pass your own object or text or any thing as Entity class)\r\n\t * ## Once after completion of request object means after providing the webaddress to it we can able to send the \r\n\t * Header Parameters and cookie parameters to it \r\n\t * \r\n\t * Here Invocation invocation = invocationBuilder.build(\"GET\");\r\n\t * or\r\n\t * Invocation invocation = invocationBuilder.buildGet();\r\n\t * Then invocation.invoke() or invocation.invoke(ClassType) so that it will invoke the target class resource \r\n\t * \r\n\t * or \r\n\t * Response response = invocationBuilder.get() \r\n\t * Here This class contains one builder method that internally creates Invoke object and and it will invoke on it and \r\n\t * it will return Response to us directly\r\n\t * \r\n\t * \r\n\t * */\r\n\t Invocation invocation = invocationBuilder.buildGet();\r\n\t Response response = invocation.invoke();\r\n\t if(response.getStatus() == 200) {\r\n\t\t System.out.println(\"inside if block\");\r\n\t\t response.bufferEntity(); //To strore in buffer before closing outputstream \r\n\t\t message = response.readEntity(String.class);\r\n\t }\r\n\t return message;\r\n }", "@GET(\"posts/1\")\n public Call<Post> getPost();", "@Test\n\tpublic void testGetVehicleModels() throws UnirestException {\n\tHttpResponse<String> response = Unirest.get(\"http://localhost:8080/TrackingVehicle/api/service/vehicleModels\")\n\t\t\t .header(\"Cache-Control\", \"no-cache\")\n\t\t\t .header(\"Postman-Token\", \"5d15aea4-c5ba-4e67-b979-42bd52ae1ccf\")\n\t\t\t .asString();\n}", "@Test\n public void getEndpoint() throws IOException {\n CloseableHttpClient httpclient = HttpClients.createDefault();\n\n //Creating a HttpGet object\n HttpPost httppost = new HttpPost(\"https://api.github.com/user/repos\");\n String auth=Credentials.getEmail()+\":\"+Credentials.getPassWard();\n byte[] encodedAuth = Base64.encodeBase64(auth.getBytes(Charset.forName(\"ISO-8859-1\")));\n String authHeader=\"Basic \"+new String(encodedAuth);\n httppost.setHeader(HttpHeaders.AUTHORIZATION,authHeader);\n String json=\"{\\\"name\\\": \\\"ploiko\\\"}\";\n httppost.setEntity(new StringEntity(json, ContentType.APPLICATION_JSON));\n HttpResponse httpresponse = httpclient.execute(httppost);\n System.out.println(httpresponse.getStatusLine());\n int actual=httpresponse.getStatusLine().getStatusCode();\n Assert.assertEquals(actual,201);\n //System.out.println(getHeaders(httpresponse,\"Access-Control-Allow-Methods\"));\n //System.out.println(httpresponse.getAllHeaders().toString());\n\n }", "@RequestMapping(\"/get\")\n\tpublic void get(String id) throws Exception {\n\n\t\tList<ServiceInstance> list = this.discoveryClient.getInstances(\"FEIGN-API\");\n String uri = \"\";\n for (ServiceInstance instance : list) {\n if (instance.getUri() != null && !\"\".equals(instance.getUri())) {\n uri = instance.getUri().toString();\n\t\t\t\tSystem.out.println(uri);\n //break;\n }\n }\n\t\tSystem.out.println(uri+\"/provide/user/get?id=2\" + \"===>\");\n // return uri+\"/provide/user/getInfo\";\n\n//\t\tString baStr = restTemplate.getForObject(uri+\"/provide/user/get?id=2\", String.class );\n//\t\tSystem.out.println(baStr+\"===>\");\n\t\treturn (String) this.userFeignService.get(id);\n\t\t//return \"sss\";\n\t}", "private org.json.JSONObject getUserInfo(String url, String token) throws Exception {\n log.info(\"Entering getUserInfo\");\n RestTemplate restTemplateWithInterceptors = new RestTemplate();\n HttpStatus status = null;\n org.json.JSONObject body = null;\n String message = null;\n\n if(!token.substring(0, 7).equals(\"Bearer \")) {\n token = \"Bearer \" + token;\n }\n log.info(\"Just added Bearer as token prefix\");\n\n try {\n List<ClientHttpRequestInterceptor> interceptors = restTemplateWithInterceptors.getInterceptors();\n if (CollectionUtils.isEmpty(interceptors)) {\n interceptors = new ArrayList<>();\n }\n\n interceptors.add(new XCIJVUserInfoHeaderInjectorInterceptor(token));\n restTemplateWithInterceptors.setInterceptors(interceptors);\n log.info(\"Just set interceptor to list\");\n HttpHeaders headers = new HttpHeaders();\n HttpEntity<?> entityUserInfo = new HttpEntity<>(headers);\n log.info(\"HttpEntity<?> entityUserInfo: {}\", entityUserInfo);\n log.info(\"getUserInfo: url: {}\", url);\n HttpEntity<String> response = restTemplateWithInterceptors.exchange(url, HttpMethod.GET, entityUserInfo, String.class);\n log.info(\"Just did carrier userinfo REST call using userinfo_endpoint\");\n body = new org.json.JSONObject(response.getBody());\n\n } catch (RestClientResponseException e) {\n\n if (e.getRawStatusCode() == 401) {\n status = HttpStatus.UNAUTHORIZED;\n message = \"Unauthorized token\";\n log.error(\"HTTP 401: \" + message);\n throw new OauthException(message, status);\n }\n\n if (e.getResponseBodyAsByteArray().length > 0) {\n message = new String(e.getResponseBodyAsByteArray());\n } else {\n message = e.getMessage();\n }\n status = HttpStatus.BAD_REQUEST;\n log.error(\"HTTP 400: \" + message);\n throw new OauthException(message, status);\n\n } catch (Exception e) {\n message = \"Error in calling Bank app end point\" + e.getMessage();\n status = HttpStatus.INTERNAL_SERVER_ERROR;\n log.error(\"HTTP 500: \" + message);\n throw new OauthException(message, status);\n }\n log.info(\"Leaving getUserInfo\");\n\n return body;\n }", "private Transaction callPaymentServiceApi(Transaction paymentDetails) {\n HttpHeaders headers = new HttpHeaders();\n headers.setAccept(Arrays.asList(MediaType.APPLICATION_JSON));\n HttpEntity<Transaction> entity = new HttpEntity<Transaction>(paymentDetails,headers);\n\n return restTemplate.exchange(\n \"http://localhost:8083/transaction\", HttpMethod.POST, entity, Transaction.class).getBody();\n }", "@Test\n\tpublic void latest_Client() throws ClientProtocolException, IOException\n {\n CloseableHttpClient httpclinet2=HttpClientBuilder.create().build();\n \n // 2 Url purpose\n HttpGet httpget= new HttpGet(\"https://reqres.in\");\n \n // 3 Add Header\n\t httpget.addHeader(\"Authorization\",\"Bearer_ HGHKHGKHGKGKHGHGHJGKHGK\");\n\t \n\t /*********4 execute the API and store response************/ \n\t CloseableHttpResponse response= httpclinet2.execute(httpget);\n\t \n\t // Read the status code\n\t int i= response.getStatusLine().getStatusCode();\n\t System.out.println(i);\n\t Assert.assertEquals(200, i);\n\t \n\t //Print the response and store the response in string, here you cannot directly store the response and print.\n\t HttpEntity entity= response.getEntity();\n\t String data=EntityUtils.toString(entity);\n\t System.out.println(data);\n\t \n\t //GetJson value using Rest Assured Jsonpath value\n\t JsonPath json=new JsonPath(data);\n\t String dataapi=json.getString(\"Meta_.id\");\n\t System.out.println(dataapi);\n\t \n\t //working on Jway API alternative of jpath to retrieve the value.\n\t \n\t \n\t \n\t \n\t \n\t \n\t \n\t \n\t \n\t \n\t \n }" ]
[ "0.8005843", "0.777351", "0.73739356", "0.70996344", "0.6841413", "0.68291587", "0.677741", "0.6678732", "0.66500646", "0.65845525", "0.65720344", "0.657165", "0.65324175", "0.65177375", "0.64861244", "0.64706403", "0.6464261", "0.642272", "0.6411101", "0.63878065", "0.63835305", "0.63776237", "0.6348306", "0.633955", "0.6337812", "0.6323555", "0.6314681", "0.6292547", "0.6283079", "0.6270189", "0.6258287", "0.62566537", "0.6242209", "0.6215748", "0.62096894", "0.6209438", "0.62033063", "0.6202792", "0.6159819", "0.6131193", "0.6117828", "0.6069771", "0.6061223", "0.60386264", "0.60380435", "0.60357296", "0.6020976", "0.6008121", "0.59998304", "0.59888536", "0.5956444", "0.5952824", "0.59453785", "0.59367687", "0.5895182", "0.5889625", "0.5883915", "0.5881392", "0.58751386", "0.58686876", "0.5863111", "0.5855293", "0.5823739", "0.5820199", "0.5800422", "0.5793481", "0.57724226", "0.57646316", "0.5736507", "0.570961", "0.5709321", "0.5707606", "0.5700679", "0.5693187", "0.56924725", "0.568985", "0.56848305", "0.56817114", "0.5670212", "0.56584007", "0.56582534", "0.56574905", "0.5625054", "0.56195086", "0.5599998", "0.55924875", "0.55795723", "0.5571156", "0.5568564", "0.55546284", "0.55515575", "0.55503833", "0.5546717", "0.55441195", "0.5541329", "0.55382985", "0.5535517", "0.55345416", "0.5526098", "0.5514673", "0.55089927" ]
0.0
-1
$FF: renamed from: (net.minecraft.server.MinecraftServer, j9, java.lang.String, int, dt, qi) void
public void method_2239(MinecraftServer param1, class_29 param2, String param3, int param4, class_1045 param5, class_1535 param6) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public interface C5861g {\n /* renamed from: a */\n void mo18320a(C7251a aVar);\n\n @Deprecated\n /* renamed from: a */\n void mo18321a(C7251a aVar, String str);\n\n /* renamed from: a */\n void mo18322a(C7252b bVar);\n\n /* renamed from: a */\n void mo18323a(C7253c cVar);\n\n /* renamed from: a */\n void mo18324a(C7260j jVar);\n}", "interface C33292a {\n /* renamed from: a */\n void mo85415a(String str);\n }", "public interface C2368d {\n\n /* renamed from: com.google.android.exoplayer2.upstream.d$a */\n public interface C2367a {\n /* renamed from: a */\n C2368d mo1698a();\n }\n\n /* renamed from: a */\n int mo1684a(byte[] bArr, int i, int i2);\n\n /* renamed from: a */\n long mo1685a(C2369e c2369e);\n\n /* renamed from: a */\n Uri mo1686a();\n\n /* renamed from: b */\n void mo1687b();\n}", "public interface C39682m {\n\n /* renamed from: com.ss.android.ugc.aweme.shortvideo.edit.m$a */\n public interface C39683a {\n /* renamed from: a */\n int mo98966a(C29296g gVar);\n\n /* renamed from: b */\n int mo98967b(C29296g gVar);\n\n /* renamed from: c */\n float mo98968c(C29296g gVar);\n }\n\n /* renamed from: com.ss.android.ugc.aweme.shortvideo.edit.m$b */\n public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }\n}", "public interface C1656t {\n /* renamed from: a */\n void mo7350a();\n\n /* renamed from: a */\n void mo7351a(C1655s sVar);\n\n /* renamed from: a */\n void mo7352a(C1655s sVar, AdError adError);\n\n /* renamed from: b */\n void mo7353b();\n\n /* renamed from: b */\n void mo7354b(C1655s sVar);\n\n /* renamed from: c */\n void mo7355c(C1655s sVar);\n\n /* renamed from: d */\n void mo7356d(C1655s sVar);\n\n /* renamed from: e */\n void mo7357e(C1655s sVar);\n\n /* renamed from: f */\n void mo7358f(C1655s sVar);\n}", "public interface C23407b {\n /* renamed from: a */\n void mo60892a();\n\n /* renamed from: b */\n void mo60893b();\n }", "public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "public interface C6788a {\n /* renamed from: a */\n void mo20141a();\n }", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public interface C30793j {\n /* renamed from: a */\n void mo80452a();\n\n /* renamed from: a */\n void mo80453a(Message message);\n\n /* renamed from: a */\n void mo80454a(File file, long j);\n\n /* renamed from: b */\n void mo80455b();\n\n /* renamed from: b */\n void mo80456b(Message message);\n\n /* renamed from: c */\n void mo80457c();\n}", "public interface C0779a {\n /* renamed from: a */\n void mo2311a();\n}", "public interface C16740s extends IInterface {\n /* renamed from: a */\n void mo43357a(C16726e eVar) throws RemoteException;\n}", "public interface C38422j {\n /* renamed from: nm */\n void mo6247nm(int i);\n}", "public interface C22932f {\n /* renamed from: a */\n void mo59932a(String str, JSONObject jSONObject);\n}", "public interface C8326b {\n /* renamed from: a */\n C8325a mo21498a(String str);\n\n /* renamed from: a */\n void mo21499a(C8325a aVar);\n}", "public interface C15428f {\n\n /* renamed from: com.ss.android.ugc.asve.context.f$a */\n public static final class C15429a {\n /* renamed from: a */\n public static String m45146a(C15428f fVar) {\n return \"\";\n }\n\n /* renamed from: b */\n public static String m45147b(C15428f fVar) {\n return \"\";\n }\n }\n\n /* renamed from: a */\n boolean mo38970a();\n\n /* renamed from: b */\n String mo38971b();\n\n /* renamed from: c */\n String mo38972c();\n\n /* renamed from: d */\n int mo38973d();\n\n /* renamed from: e */\n int mo38974e();\n}", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "static MinecraftServer b(NetLoginHandler var0)\n {\n return var0.server;\n }", "public interface C2672h {\n /* renamed from: a */\n void mo1927a(NLPResponseData nLPResponseData);\n\n /* renamed from: a */\n void mo1931a(C2848p c2848p);\n\n /* renamed from: a */\n void mo1932a(String str);\n\n /* renamed from: b */\n void mo1933b(int i);\n\n /* renamed from: b */\n void mo1934b(String str);\n\n /* renamed from: c */\n void mo1935c(String str);\n\n /* renamed from: i */\n void mo1940i();\n\n /* renamed from: j */\n void mo1941j();\n\n /* renamed from: k */\n void mo1942k();\n\n /* renamed from: l */\n void mo1943l();\n}", "public interface C24221b extends C28343z<C28318an> {\n /* renamed from: a */\n void mo62991a(int i);\n\n String aw_();\n\n /* renamed from: e */\n Aweme mo62993e();\n}", "public interface C3210f extends C11871b<DeletedProgramBroadcastReceiver> {\n\n /* renamed from: com.bamtechmedia.dominguez.channels.tv.f$a */\n /* compiled from: FeatureChannelModule_ProvidesWatchNextProgramBroadcastReceiver */\n public interface C3211a extends C11872a<DeletedProgramBroadcastReceiver> {\n }\n}", "public interface C26438t {\n /* renamed from: b */\n void mo5959b(boolean z, String str, Bundle bundle);\n}", "public interface C0237a {\n /* renamed from: a */\n void mo1791a(String str);\n }", "public interface C18928d {\n /* renamed from: a */\n void mo50320a(C18924b bVar);\n\n /* renamed from: b */\n void mo50321b(C18924b bVar);\n}", "public interface C42593b {\n /* renamed from: H */\n void mo34677H(String str, int i, int i2);\n\n void aFq();\n\n void aFr();\n\n void aFs();\n\n void aFt();\n\n void aFu();\n\n void aFv();\n\n /* renamed from: de */\n void mo34684de(int i, int i2);\n }", "public interface C35013b {\n /* renamed from: a */\n void mo88773a(int i);\n}", "public interface C1799a {\n /* renamed from: b */\n void mo3314b(String str);\n }", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "public interface C0657b {\n /* renamed from: f */\n void mo3193f();\n\n /* renamed from: r */\n void mo3194r();\n}", "public interface C9715b {\n\n /* renamed from: com.tencent.mm.modelvideo.b$a */\n public interface C9714a {\n /* renamed from: ad */\n void mo9058ad(String str, int i);\n\n /* renamed from: h */\n void mo9075h(String str, int i, int i2);\n\n /* renamed from: ml */\n void mo21050ml(int i);\n\n void onDataAvailable(String str, int i, int i2);\n }\n\n /* renamed from: a */\n void mo8712a(C9714a c9714a);\n\n /* renamed from: dV */\n void mo8713dV(String str);\n\n boolean isVideoDataAvailable(String str, int i, int i2);\n\n /* renamed from: r */\n void mo8715r(String str, String str2, String str3);\n\n void requestVideoData(String str, int i, int i2);\n}", "interface C1403bj {\n /* renamed from: iS */\n C1458cs mo7613iS();\n\n /* renamed from: jh */\n C1436ck mo7614jh();\n}", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "public interface C4211a {\n\n /* renamed from: com.iab.omid.library.oguryco.c.a$a */\n public interface C4212a {\n /* renamed from: a */\n void mo28760a(View view, C4211a aVar, JSONObject jSONObject);\n }\n\n /* renamed from: a */\n JSONObject mo28758a(View view);\n\n /* renamed from: a */\n void mo28759a(View view, JSONObject jSONObject, C4212a aVar, boolean z);\n}", "public interface C11316t5 extends C11259p5, Cloneable {\n /* renamed from: j0 */\n C11316t5 mo29022j0();\n}", "public interface C45101e {\n /* renamed from: b */\n void mo3796b(int i);\n}", "@Deprecated\n\tprivate void oldCode()\n\t{\n\t}", "public interface C2367a {\n /* renamed from: a */\n C2368d mo1698a();\n }", "public interface am extends ak {\r\n /* renamed from: a */\r\n void mo194a(int i) throws RemoteException;\r\n\r\n /* renamed from: a */\r\n void mo195a(List<LatLng> list) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo196b(float f) throws RemoteException;\r\n\r\n /* renamed from: b */\r\n void mo197b(boolean z);\r\n\r\n /* renamed from: c */\r\n void mo198c(boolean z) throws RemoteException;\r\n\r\n /* renamed from: g */\r\n float mo199g() throws RemoteException;\r\n\r\n /* renamed from: h */\r\n int mo200h() throws RemoteException;\r\n\r\n /* renamed from: i */\r\n List<LatLng> mo201i() throws RemoteException;\r\n\r\n /* renamed from: j */\r\n boolean mo202j();\r\n\r\n /* renamed from: k */\r\n boolean mo203k();\r\n}", "public interface C3222n extends IInterface {\n /* renamed from: a */\n void mo13025a() throws RemoteException;\n\n /* renamed from: b */\n void mo13026b() throws RemoteException;\n}", "public interface C24340v {\n /* renamed from: q */\n void mo63094q();\n}", "public interface C0087c {\n /* renamed from: a */\n String mo150a(String str);\n}", "public interface C4521a {\n /* renamed from: a */\n void mo12348a();\n }", "public interface C5728f {\n /* renamed from: a */\n int mo33223a(C5889d dVar) throws IOException;\n\n /* renamed from: a */\n C5727e mo33224a();\n\n @Deprecated\n /* renamed from: a */\n boolean mo33287a(int i) throws IOException;\n\n int read() throws IOException;\n\n int read(byte[] bArr, int i, int i2) throws IOException;\n}", "public interface C0456a {\n /* renamed from: a */\n void mo2090a(C0455b bVar);\n\n /* renamed from: a */\n boolean mo2091a(C0455b bVar, Menu menu);\n\n /* renamed from: a */\n boolean mo2092a(C0455b bVar, MenuItem menuItem);\n\n /* renamed from: b */\n boolean mo2093b(C0455b bVar, Menu menu);\n }", "public interface C4869f {\n /* renamed from: a */\n C4865b mo6249a();\n}", "public interface C11994b {\n /* renamed from: a */\n C11996a mo41079a(String str);\n\n /* renamed from: a */\n C11996a mo41080a(String str, C11997b bVar, String... strArr);\n\n /* renamed from: a */\n C11998c mo41081a(String str, C11999d dVar, String... strArr);\n\n /* renamed from: a */\n C12000e mo41082a(String str, C12001f fVar, String... strArr);\n\n /* renamed from: a */\n void mo41083a();\n\n /* renamed from: a */\n void mo41084a(C12018b bVar, ConnectionState... connectionStateArr);\n\n /* renamed from: b */\n C11996a mo41085b(String str);\n\n /* renamed from: b */\n void mo41086b();\n\n /* renamed from: c */\n C12000e mo41087c(String str);\n\n /* renamed from: c */\n C12017a mo41088c();\n\n /* renamed from: d */\n void mo41089d(String str);\n\n /* renamed from: e */\n C11998c mo41090e(String str);\n\n /* renamed from: f */\n C12000e mo41091f(String str);\n\n /* renamed from: g */\n C11998c mo41092g(String str);\n}", "interface C0932a {\n /* renamed from: a */\n void mo7438a(int i, int i2);\n\n /* renamed from: b */\n void mo7439b(C0933b bVar);\n\n /* renamed from: c */\n void mo7440c(int i, int i2, Object obj);\n\n /* renamed from: d */\n void mo7441d(C0933b bVar);\n\n /* renamed from: e */\n RecyclerView.ViewHolder mo7442e(int i);\n\n /* renamed from: f */\n void mo7443f(int i, int i2);\n\n /* renamed from: g */\n void mo7444g(int i, int i2);\n\n /* renamed from: h */\n void mo7445h(int i, int i2);\n }", "public interface C4150sl {\n /* renamed from: a */\n void mo15005a(C4143se seVar);\n}", "public void mo21825b() {\n }", "public interface C28392h {\n /* renamed from: a */\n void mo72111a();\n\n /* renamed from: a */\n void mo72112a(float f);\n\n /* renamed from: b */\n void mo72113b();\n\n /* renamed from: c */\n void mo72114c();\n\n /* renamed from: d */\n boolean mo72115d();\n\n void dismiss();\n}", "interface bxc {\n /* renamed from: a */\n void mo2508a(bxb bxb);\n}", "public interface C1529m {\n /* renamed from: a */\n void mo3767a(int i);\n\n /* renamed from: a */\n void mo3768a(String str);\n}", "public interface C5138c {\n /* renamed from: e */\n void mo25968e(TemplateInfo templateInfo);\n\n /* renamed from: f */\n void mo25969f(TemplateInfo templateInfo);\n}", "public interface C2459d {\n /* renamed from: a */\n C2451d mo3408a(C2457e c2457e);\n}", "public interface C0303q extends C0291e {\n /* renamed from: a */\n void mo1747a(int i);\n\n /* renamed from: a */\n void mo1749a(C0288c cVar);\n\n /* renamed from: a */\n void mo1751a(byte[] bArr);\n\n /* renamed from: b */\n void mo1753b(int i);\n\n /* renamed from: c */\n void mo1754c(int i);\n\n /* renamed from: d */\n void mo1755d(int i);\n\n /* renamed from: e */\n int mo1756e(int i);\n\n /* renamed from: g */\n int mo1760g();\n\n /* renamed from: g */\n void mo1761g(int i);\n\n /* renamed from: h */\n void mo1763h(int i);\n}", "public interface C43470b {\n /* renamed from: a */\n void mo61496a(C43469a aVar, C43471c cVar);\n }", "public interface C3819a {\n /* renamed from: a */\n void mo23214a(Message message);\n }", "public interface C1803l extends C1813t {\n /* renamed from: b */\n C1803l mo7382b(C2778au auVar);\n\n /* renamed from: f */\n List<C1700ar> mo7233f();\n\n /* renamed from: g */\n C2841w mo7234g();\n\n /* renamed from: q */\n C1800i mo7384q();\n}", "public interface C5101b {\n /* renamed from: a */\n void mo5289a(C5102c c5102c);\n\n /* renamed from: b */\n void mo5290b(C5102c c5102c);\n}", "public interface C48855s {\n\n /* renamed from: a */\n public static final C48856a f124209a = C48856a.f124210a;\n\n /* renamed from: shark.s$a */\n public static final class C48856a {\n\n /* renamed from: a */\n static final /* synthetic */ C48856a f124210a = new C48856a();\n\n private C48856a() {\n }\n }\n\n /* renamed from: a */\n void mo123342a(C48857t tVar);\n}", "public interface C19512d {\n /* renamed from: dd */\n void mo34676dd(int i, int i2);\n }", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "public interface C1061nc extends IInterface {\n /* renamed from: a */\n String mo2800a();\n\n /* renamed from: a */\n String mo2801a(String str);\n\n /* renamed from: a */\n void mo2802a(String str, boolean z);\n\n /* renamed from: a */\n boolean mo2803a(boolean z);\n}", "protected void onSwapCraft(int debug1) {}", "public interface C2604b {\n /* renamed from: a */\n void mo1886a(String str, String str2);\n\n /* renamed from: a */\n boolean mo1887a(String str);\n\n /* renamed from: b */\n String mo1888b(String str, String str2, String str3, String str4);\n }", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "public interface C32231g {\n /* renamed from: a */\n void mo8280a(int i, int i2, C1207m c1207m);\n}", "public void mo21877s() {\n }", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "public interface C2603a {\n /* renamed from: a */\n String mo1889a(String str, String str2, String str3, String str4);\n }", "AnonymousClass2(android.telecom.ConnectionServiceAdapterServant r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e8 in method: android.telecom.ConnectionServiceAdapterServant.2.<init>(android.telecom.ConnectionServiceAdapterServant):void, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.telecom.ConnectionServiceAdapterServant.2.<init>(android.telecom.ConnectionServiceAdapterServant):void\");\n }", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "public interface C1234b {\r\n /* renamed from: a */\r\n void m8367a();\r\n\r\n /* renamed from: b */\r\n void m8368b();\r\n}", "public interface C3042d {\n\n /* renamed from: a */\n public static final C3042d f7956a = new C3042d() {\n /* renamed from: a */\n public int mo27480a() {\n return 0;\n }\n\n /* renamed from: a */\n public Bitmap mo27481a(String str) {\n return null;\n }\n\n /* renamed from: a */\n public void mo27482a(String str, Bitmap bitmap) {\n }\n\n /* renamed from: b */\n public int mo27483b() {\n return 0;\n }\n };\n\n /* renamed from: a */\n int mo27480a();\n\n /* renamed from: a */\n Bitmap mo27481a(String str);\n\n /* renamed from: a */\n void mo27482a(String str, Bitmap bitmap);\n\n /* renamed from: b */\n int mo27483b();\n}", "public interface C40453c {\n /* renamed from: a */\n void mo100442a(C40429b bVar);\n\n /* renamed from: a */\n void mo100443a(List<String> list);\n\n /* renamed from: b */\n void mo100444b(List<C40429b> list);\n}", "public interface C4724o {\n /* renamed from: a */\n void mo4872a(int i, String str);\n\n /* renamed from: a */\n void mo4873a(C4718l c4718l);\n\n /* renamed from: b */\n void mo4874b(C4718l c4718l);\n}", "public void mo21878t() {\n }", "public interface dkj extends Cloneable, dkl {\n /* renamed from: a */\n dkj mo4367a(dkk dkk);\n\n /* renamed from: f */\n dkk mo4508f();\n\n /* renamed from: g */\n dkk mo4509g();\n}", "public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }", "@SuppressWarnings(\"unused\")\n\tprivate void version() {\n\n\t}", "public interface C4924c {\n /* renamed from: a */\n HttpRequest mo6260a(HttpMethod httpMethod, String str, Map<String, String> map);\n}", "public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }", "public interface C0025k {\n /* renamed from: a */\n long mo49a();\n}", "public void mo1406f() {\n }", "public interface C4932q5 extends C4994t5, Cloneable {\n /* renamed from: B */\n C4945r5 mo19056B();\n\n /* renamed from: F */\n C4945r5 mo19057F();\n\n /* renamed from: a */\n C4932q5 mo19393a(C4945r5 r5Var);\n\n /* renamed from: a */\n C4932q5 mo19394a(byte[] bArr) throws zzfn;\n\n /* renamed from: a */\n C4932q5 mo19395a(byte[] bArr, C5005u3 u3Var) throws zzfn;\n}", "public interface C11113o {\n /* renamed from: a */\n void mo37759a(String str);\n }", "public interface DownloadController {\n /* renamed from: a */\n int mo44964a();\n\n /* renamed from: b */\n int mo44965b();\n\n /* renamed from: c */\n boolean mo44966c();\n\n /* renamed from: d */\n boolean mo44967d();\n}", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "public interface C2836e {\n /* renamed from: a */\n InputStream mo1151a();\n\n /* renamed from: b */\n String mo1152b();\n\n /* renamed from: c */\n String[] mo1153c();\n\n /* renamed from: d */\n long mo1154d();\n}", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "public static void method_742(f6m var0, Minecraft var1) {\n var0.c = var1;\n }", "public interface C1250dr extends IInterface {\n /* renamed from: a */\n void mo12504a(brw brw, C0719a aVar);\n}", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "public interface C10702b {\n /* renamed from: a */\n C10667n mo27516a(C10652e eVar, C10695h hVar, C10703m mVar, Context context);\n }", "public interface C39683a {\n /* renamed from: a */\n int mo98966a(C29296g gVar);\n\n /* renamed from: b */\n int mo98967b(C29296g gVar);\n\n /* renamed from: c */\n float mo98968c(C29296g gVar);\n }", "public interface C2567c {\n /* renamed from: a */\n void mo10604a(Object obj, AdUnit adUnit, C2465w wVar);\n\n /* renamed from: a */\n boolean mo10605a(Object obj);\n}", "public interface C19045k {\n /* renamed from: a */\n void mo50368a(int i, Object obj);\n\n /* renamed from: b */\n void mo50369b(int i, Object obj);\n}", "AnonymousClass1(android.telecom.ConnectionServiceAdapterServant r1) {\n /*\n // Can't load method instructions: Load method exception: bogus opcode: 00e8 in method: android.telecom.ConnectionServiceAdapterServant.1.<init>(android.telecom.ConnectionServiceAdapterServant):void, dex: \n */\n throw new UnsupportedOperationException(\"Method not decompiled: android.telecom.ConnectionServiceAdapterServant.1.<init>(android.telecom.ConnectionServiceAdapterServant):void\");\n }" ]
[ "0.6057025", "0.5948664", "0.5845749", "0.57851195", "0.5717523", "0.571006", "0.5665805", "0.5664072", "0.5644524", "0.5632785", "0.563242", "0.55987746", "0.55846983", "0.55834943", "0.55787", "0.55765796", "0.55753875", "0.5575304", "0.5563456", "0.5560263", "0.55584866", "0.554881", "0.5544619", "0.5538223", "0.55342966", "0.5522081", "0.55184853", "0.5511461", "0.55093575", "0.54998976", "0.5497914", "0.5497629", "0.54950285", "0.54906356", "0.54841787", "0.5473521", "0.54708", "0.5460663", "0.5456274", "0.54459524", "0.5444881", "0.5444578", "0.5423821", "0.5422215", "0.54074025", "0.54023635", "0.54006124", "0.5390638", "0.53893864", "0.53868663", "0.53741294", "0.5372911", "0.5368767", "0.53582287", "0.5353", "0.5349761", "0.5344473", "0.5343321", "0.5330681", "0.53180915", "0.5308785", "0.53060836", "0.5300153", "0.5294742", "0.5294119", "0.5281433", "0.5281391", "0.5269411", "0.52643293", "0.52551895", "0.52510107", "0.52501124", "0.5236181", "0.5235042", "0.523333", "0.52283156", "0.52252305", "0.52222925", "0.52168214", "0.520987", "0.520855", "0.5199068", "0.5196375", "0.51946974", "0.51880693", "0.5184035", "0.5179368", "0.51783496", "0.5162926", "0.5158121", "0.51568455", "0.51555324", "0.51445353", "0.513805", "0.513303", "0.5130268", "0.5130217", "0.51269543", "0.512556", "0.5120395" ]
0.65723306
0
$FF: renamed from: b () void
public void method_2139() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void b() {\r\n }", "@Override\n public void b() {\n }", "public void b() {\n }", "public void b() {\n }", "@Override\n\tpublic void b() {\n\n\t}", "void b();", "@Override\n\tpublic void b1() {\n\t\t\n\t}", "@Override\n\tpublic void bbb() {\n\t\t\n\t}", "@Override\n public void func_104112_b() {\n \n }", "void mo2508a(bxb bxb);", "@Override\n\tpublic void b2() {\n\t\t\n\t}", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void mo80455b();", "public abstract int b();", "void mo41086b();", "@Override\n\tpublic void b() {\n\t\tSystem.out.println(\"b method\");\n\t\t\n\t}", "public abstract void mo70713b();", "void mo67923b();", "void mo88523b();", "void mo57277b();", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "void mo72113b();", "void mo119582b();", "public void mo115190b() {\n }", "public abstract void mo70702a(C30989b c30989b);", "public void mo21825b() {\n }", "public static void bi() {\n\t}", "public final void mo1285b() {\n }", "public final /* bridge */ /* synthetic */ void mo43569b() {\n super.mo43569b();\n }", "public abstract void mo6549b();", "public void a() {\r\n }", "public abstract void mo35054b();", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public void mo9137b() {\n }", "public abstract void mo45765b();", "public int b()\r\n/* 69: */ {\r\n/* 70:74 */ return this.b;\r\n/* 71: */ }", "public abstract void mo4360a(byte b);", "@Override\n\tpublic void a() {\n\t\t\n\t}", "public void a() {\n }", "public void a() {\n }", "void mo7353b();", "void mo28194a();", "protected void a(bug parambug)\r\n/* 35: */ {\r\n/* 36:36 */ this.j.a((bxf)null);\r\n/* 37: */ }", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "public abstract void mo957b();", "public abstract C0631bt mo9227aB();", "public abstract void b(StringBuilder sb);", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "public abstract void mo9798a(byte b);", "public void mo5097b() {\n }", "public abstract void mo9246b(C0707b bVar);", "void mo4833b();", "public void mo23438b() {\n }", "public /* bridge */ /* synthetic */ void mo55095b() {\n super.mo55095b();\n }", "public void b(amj paramamj)\r\n/* 538: */ {\r\n/* 539:579 */ this.f = paramamj;\r\n/* 540: */ }", "public abstract int mo4375b();", "void mo60893b();", "public void b(ahd paramahd) {}", "void mo12637b();", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "public void b(Object obj) {\n e();\n }", "public void b(gy ☃) {}\r\n/* */ \r\n/* */ \r\n/* */ \r\n/* */ public void a(gy ☃) {}", "public final void mo8775b() {\n }", "protected abstract void a(bru parambru);", "void mo80452a();", "public final void b() {\n /*\n r10 = this;\n r0 = 0\n java.lang.Object[] r1 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r3 = f53248e\n java.lang.Class[] r6 = new java.lang.Class[r0]\n java.lang.Class r7 = java.lang.Void.TYPE\n r4 = 0\n r5 = 55479(0xd8b7, float:7.7743E-41)\n r2 = r10\n boolean r1 = com.meituan.robust.PatchProxy.isSupport(r1, r2, r3, r4, r5, r6, r7)\n if (r1 == 0) goto L_0x0025\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = f53248e\n r5 = 0\n r6 = 55479(0xd8b7, float:7.7743E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r10\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x0025:\n com.ss.android.ugc.aweme.live.alphaplayer.e$i r9 = r10.h\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r5 = 0\n r6 = 55516(0xd8dc, float:7.7794E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n boolean r2 = com.meituan.robust.PatchProxy.isSupport(r2, r3, r4, r5, r6, r7, r8)\n if (r2 == 0) goto L_0x004b\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r5 = 0\n r6 = 55516(0xd8dc, float:7.7794E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x004b:\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r2 = g\n monitor-enter(r2)\n r0 = 1\n r9.f53270c = r0 // Catch:{ all -> 0x006e }\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = g // Catch:{ all -> 0x006e }\n r0.notifyAll() // Catch:{ all -> 0x006e }\n L_0x0056:\n boolean r0 = r9.f53269b // Catch:{ all -> 0x006e }\n if (r0 != 0) goto L_0x006c\n boolean r0 = r9.f53271d // Catch:{ all -> 0x006e }\n if (r0 != 0) goto L_0x006c\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = g // Catch:{ InterruptedException -> 0x0064 }\n r0.wait() // Catch:{ InterruptedException -> 0x0064 }\n goto L_0x0056\n L_0x0064:\n java.lang.Thread r0 = java.lang.Thread.currentThread() // Catch:{ all -> 0x006e }\n r0.interrupt() // Catch:{ all -> 0x006e }\n goto L_0x0056\n L_0x006c:\n monitor-exit(r2) // Catch:{ all -> 0x006e }\n return\n L_0x006e:\n r0 = move-exception\n monitor-exit(r2) // Catch:{ all -> 0x006e }\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.b():void\");\n }", "protected b(int mb) {\n/* 87 */ this.b = mb;\n/* */ }", "public void f() {\n if (this instanceof b) {\n b bVar = (b) this;\n Message q_ = bVar.q_();\n e.c().a(new f(bVar.b(), q_.toByteArray()), getClass().getSimpleName(), i().a(), q_);\n return;\n }\n f a2 = a();\n if (a2 != null) {\n e.c().a(a2, getClass().getSimpleName(), i().a(), (Message) null);\n }\n }", "public /* bridge */ /* synthetic */ void mo55094a() {\n super.mo55094a();\n }", "void mo50320a(C18924b bVar);", "void mo7439b(C0933b bVar);", "public abstract Object mo1185b();", "void mo50321b(C18924b bVar);", "void mo18322a(C7252b bVar);", "public abstract int b(int i2, int i3);", "public abstract BoundType b();", "public abstract void mo9809b(int i);", "void mo71b();", "void mo41083a();", "public static void a() {\n\n }", "public np a()\r\n/* 33: */ {\r\n/* 34:49 */ return this.b;\r\n/* 35: */ }", "public abstract void mo42329d();", "void m8368b();", "public void mo23813b() {\n }", "void mo1970b();", "void mo46242a(bmc bmc);", "public void mo5251b() {\n }", "public abstract void mo53562a(C18796a c18796a);", "void mo100442a(C40429b bVar);", "public abstract void mo102899a();", "public void mo3287b() {\n }", "void mo54405a();", "public final void b() {\n /*\n r9 = this;\n r0 = 0\n java.lang.Object[] r1 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r3 = f53268a\n java.lang.Class[] r6 = new java.lang.Class[r0]\n java.lang.Class r7 = java.lang.Void.TYPE\n r4 = 0\n r5 = 55519(0xd8df, float:7.7799E-41)\n r2 = r9\n boolean r1 = com.meituan.robust.PatchProxy.isSupport(r1, r2, r3, r4, r5, r6, r7)\n if (r1 == 0) goto L_0x0025\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = f53268a\n r5 = 0\n r6 = 55519(0xd8df, float:7.7799E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x0025:\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = com.ss.android.ugc.aweme.live.alphaplayer.e.g\n monitor-enter(r0)\n r1 = 1\n r9.h = r1 // Catch:{ all -> 0x0044 }\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = com.ss.android.ugc.aweme.live.alphaplayer.e.g // Catch:{ all -> 0x0044 }\n r1.notifyAll() // Catch:{ all -> 0x0044 }\n L_0x0030:\n boolean r1 = r9.f53269b // Catch:{ all -> 0x0044 }\n if (r1 != 0) goto L_0x0042\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = com.ss.android.ugc.aweme.live.alphaplayer.e.g // Catch:{ InterruptedException -> 0x003a }\n r1.wait() // Catch:{ InterruptedException -> 0x003a }\n goto L_0x0030\n L_0x003a:\n java.lang.Thread r1 = java.lang.Thread.currentThread() // Catch:{ all -> 0x0044 }\n r1.interrupt() // Catch:{ all -> 0x0044 }\n goto L_0x0030\n L_0x0042:\n monitor-exit(r0) // Catch:{ all -> 0x0044 }\n return\n L_0x0044:\n r1 = move-exception\n monitor-exit(r0) // Catch:{ all -> 0x0044 }\n throw r1\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.i.b():void\");\n }", "void mo2090a(C0455b bVar);", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "void mo21070b();", "public abstract void mo42331g();", "void mo88521a();", "public String b()\r\n/* 35: */ {\r\n/* 36:179 */ return a();\r\n/* 37: */ }", "public abstract C0270jy mo5354b();", "public void m23075a() {\n }" ]
[ "0.8112682", "0.80767715", "0.79938555", "0.79938555", "0.798342", "0.7847682", "0.7622169", "0.75516546", "0.74865687", "0.74736917", "0.74144864", "0.72326136", "0.7230346", "0.7225043", "0.7178822", "0.71743643", "0.7171457", "0.7159698", "0.71496016", "0.71275663", "0.7123601", "0.71100324", "0.70853746", "0.70755565", "0.70496345", "0.7035567", "0.7021109", "0.69906795", "0.6985955", "0.69712156", "0.69617265", "0.6959285", "0.69411993", "0.69342977", "0.69291705", "0.6898869", "0.686011", "0.6849992", "0.684124", "0.684124", "0.68352336", "0.67828816", "0.6769877", "0.6769071", "0.67530537", "0.6743051", "0.67287844", "0.67261153", "0.67220974", "0.67200005", "0.67168564", "0.67125916", "0.6701536", "0.67013025", "0.6696176", "0.6681761", "0.6680542", "0.6675545", "0.66739774", "0.66698897", "0.6669793", "0.66528857", "0.6651571", "0.6628564", "0.6589274", "0.6584779", "0.6563783", "0.6559747", "0.6558095", "0.6557963", "0.6557916", "0.6556712", "0.6555858", "0.65548545", "0.65485364", "0.6544726", "0.65392876", "0.652908", "0.65273184", "0.6523478", "0.651869", "0.65088826", "0.650371", "0.6502098", "0.6497963", "0.6490353", "0.64883864", "0.6484858", "0.647373", "0.64635617", "0.6461991", "0.64580154", "0.6457541", "0.6456592", "0.64535564", "0.64484173", "0.64403313", "0.6439625", "0.64373183", "0.6433533", "0.6433345" ]
0.0
-1
$FF: renamed from: b (as, int, int, int) vC
public class_1653 method_2240(class_922 var1, int var2, int var3, int var4) { String[] var10000 = class_752.method_4253(); List var6 = this.method_2192().method_111(var1, var2, var3, var4); String[] var5 = var10000; class_1653 var10; label28: { List var9; label27: { try { var9 = var6; if(var5 == null) { break label27; } if(var6 == null) { break label28; } } catch (IllegalStateException var8) { throw method_2260(var8); } var9 = var6; } try { if(!var9.isEmpty()) { var10 = (class_1653)class_1725.method_9638(this.field_1819, var6); return var10; } } catch (IllegalStateException var7) { throw method_2260(var7); } } var10 = null; return var10; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "void mo2508a(bxb bxb);", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "public abstract void mo70702a(C30989b c30989b);", "void mo50321b(C18924b bVar);", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "void mo83703a(C32456b<T> bVar);", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "public void mo23981a(C4321b bVar) {\n }", "public abstract void mo9244b(C0620bi biVar);", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "void mo100442a(C40429b bVar);", "void mo50320a(C18924b bVar);", "void mo7439b(C0933b bVar);", "public void mo32543a(C6744b bVar) {\n }", "void mo18322a(C7252b bVar);", "void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);", "public abstract void zzc(B b, int i, int i2);", "void mo2090a(C0455b bVar);", "public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }", "@Override\n public void func_104112_b() {\n \n }", "public abstract void mo9246b(C0707b bVar);", "public interface C43470b {\n /* renamed from: a */\n void mo61496a(C43469a aVar, C43471c cVar);\n }", "public abstract C0631bt mo9227aB();", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public abstract void mo53562a(C18796a c18796a);", "public interface C11859a {\n void bvs();\n }", "public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }", "public interface C18928d {\n /* renamed from: a */\n void mo50320a(C18924b bVar);\n\n /* renamed from: b */\n void mo50321b(C18924b bVar);\n}", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "interface bxc {\n /* renamed from: a */\n void mo2508a(bxb bxb);\n}", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "void mo4874b(C4718l c4718l);", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "public interface C7654b {\n /* renamed from: a */\n C7904c mo24084a();\n\n /* renamed from: b */\n C7716a mo24085b();\n }", "public interface C45101e {\n /* renamed from: b */\n void mo3796b(int i);\n}", "public abstract C14407a mo11608b(int i);", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "public interface C32231g {\n /* renamed from: a */\n void mo8280a(int i, int i2, C1207m c1207m);\n}", "public /* synthetic */ void mo7209b(as asVar, bp bpVar) throws bv {\n m21417a(asVar, (bc) bpVar);\n }", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public interface C2459d {\n /* renamed from: a */\n C2451d mo3408a(C2457e c2457e);\n}", "public /* synthetic */ void mo7208a(as asVar, bp bpVar) throws bv {\n m21419b(asVar, (bc) bpVar);\n }", "interface C11601a {\n /* renamed from: tY */\n void mo23327tY(int i);\n }", "private int b(String paramString, float paramFloat1, float paramFloat2, int paramInt, boolean paramBoolean)\r\n/* 426: */ {\r\n/* 427:421 */ if (paramString == null) {\r\n/* 428:422 */ return 0;\r\n/* 429: */ }\r\n/* 430:424 */ if (this.l) {\r\n/* 431:425 */ paramString = c(paramString);\r\n/* 432: */ }\r\n/* 433:428 */ if ((paramInt & 0xFC000000) == 0) {\r\n/* 434:429 */ paramInt |= 0xFF000000;\r\n/* 435: */ }\r\n/* 436:432 */ if (paramBoolean) {\r\n/* 437:433 */ paramInt = (paramInt & 0xFCFCFC) >> 2 | paramInt & 0xFF000000;\r\n/* 438: */ }\r\n/* 439:436 */ this.m = ((paramInt >> 16 & 0xFF) / 255.0F);\r\n/* 440:437 */ this.n = ((paramInt >> 8 & 0xFF) / 255.0F);\r\n/* 441:438 */ this.o = ((paramInt & 0xFF) / 255.0F);\r\n/* 442:439 */ this.p = ((paramInt >> 24 & 0xFF) / 255.0F);\r\n/* 443: */ \r\n/* 444:441 */ cjm.c(this.m, this.n, this.o, this.p);\r\n/* 445: */ \r\n/* 446:443 */ this.i = paramFloat1;\r\n/* 447:444 */ this.j = paramFloat2;\r\n/* 448:445 */ a(paramString, paramBoolean);\r\n/* 449: */ \r\n/* 450:447 */ return (int)this.i;\r\n/* 451: */ }", "void mo5290b(C5102c c5102c);", "public void b(fv paramfv)\r\n/* 408: */ {\r\n/* 409:423 */ this.a = new amj[36];\r\n/* 410:424 */ this.b = new amj[4];\r\n/* 411:425 */ for (int i = 0; i < paramfv.c(); i++)\r\n/* 412: */ {\r\n/* 413:426 */ fn localfn = paramfv.b(i);\r\n/* 414:427 */ int j = localfn.d(\"Slot\") & 0xFF;\r\n/* 415:428 */ amj localamj = amj.a(localfn);\r\n/* 416:429 */ if (localamj != null)\r\n/* 417: */ {\r\n/* 418:430 */ if ((j >= 0) && (j < this.a.length)) {\r\n/* 419:431 */ this.a[j] = localamj;\r\n/* 420: */ }\r\n/* 421:433 */ if ((j >= 100) && (j < this.b.length + 100)) {\r\n/* 422:434 */ this.b[(j - 100)] = localamj;\r\n/* 423: */ }\r\n/* 424: */ }\r\n/* 425: */ }\r\n/* 426: */ }", "public interface C8111a {\n /* renamed from: a */\n long mo25071a(long j);\n\n /* renamed from: a */\n C8438u mo25072a(C8438u uVar);\n\n /* renamed from: a */\n AudioProcessor[] mo25073a();\n\n /* renamed from: b */\n long mo25074b();\n }", "public abstract void mo4360a(byte b);", "public interface C1436d {\n /* renamed from: a */\n C1435c mo1754a(C1433a c1433a, C1434b c1434b);\n}", "public interface C0937a {\n /* renamed from: a */\n void mo3807a(C0985po[] poVarArr);\n }", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "void mo5289a(C5102c c5102c);", "private static void m831a(C0741g<?> gVar, C0747b bVar) {\n gVar.mo9477a(C0743i.f718b, (C0739e<? super Object>) bVar);\n gVar.mo9476a(C0743i.f718b, (C0738d) bVar);\n gVar.mo9474a(C0743i.f718b, (C0736b) bVar);\n }", "public interface C0303q extends C0291e {\n /* renamed from: a */\n void mo1747a(int i);\n\n /* renamed from: a */\n void mo1749a(C0288c cVar);\n\n /* renamed from: a */\n void mo1751a(byte[] bArr);\n\n /* renamed from: b */\n void mo1753b(int i);\n\n /* renamed from: c */\n void mo1754c(int i);\n\n /* renamed from: d */\n void mo1755d(int i);\n\n /* renamed from: e */\n int mo1756e(int i);\n\n /* renamed from: g */\n int mo1760g();\n\n /* renamed from: g */\n void mo1761g(int i);\n\n /* renamed from: h */\n void mo1763h(int i);\n}", "private void m3416c(C0933b bVar) {\n m3422v(bVar);\n }", "void mo7441d(C0933b bVar);", "public abstract void mo9245b(C0631bt btVar);", "protected b(int mb) {\n/* 87 */ this.b = mb;\n/* */ }", "void mo7305b(C1070b bVar);", "void mo8712a(C9714a c9714a);", "void mo54413a(int i, C20254v vVar);", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public interface C9223b {\n }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "public abstract C7035a mo24417b(long j);", "public abstract void zzb(B b, int i, long j);", "public abstract int b(int i2, int i3);", "interface C1069a {\n /* renamed from: a */\n C1000w mo7300a(int i);\n\n /* renamed from: a */\n void mo7301a(int i, int i2);\n\n /* renamed from: a */\n void mo7302a(int i, int i2, Object obj);\n\n /* renamed from: a */\n void mo7303a(C1070b bVar);\n\n /* renamed from: b */\n void mo7304b(int i, int i2);\n\n /* renamed from: b */\n void mo7305b(C1070b bVar);\n\n /* renamed from: c */\n void mo7306c(int i, int i2);\n\n /* renamed from: d */\n void mo7308d(int i, int i2);\n }", "public void a(float paramFloat, int paramInt)\r\n/* 15: */ {\r\n/* 16:132 */ bsu.z().N().a(bvo.a);\r\n/* 17:133 */ bub.a(0, 0, 128.0F, 0.0F, 16, 16, 256.0F, 256.0F);\r\n/* 18: */ }", "void mo4103b(int i, int i2);", "public interface C0141g {\n /* renamed from: a */\n void mo84a();\n\n /* renamed from: a */\n void mo85a(int i);\n\n /* renamed from: a */\n void mo86a(C0163d c0163d);\n\n /* renamed from: a */\n void mo87a(String str);\n\n /* renamed from: a */\n void mo88a(byte[] bArr, int i, int i2);\n\n /* renamed from: b */\n C0139e mo89b();\n}", "void mo7303a(C1070b bVar);", "interface C0932a {\n /* renamed from: a */\n void mo7438a(int i, int i2);\n\n /* renamed from: b */\n void mo7439b(C0933b bVar);\n\n /* renamed from: c */\n void mo7440c(int i, int i2, Object obj);\n\n /* renamed from: d */\n void mo7441d(C0933b bVar);\n\n /* renamed from: e */\n RecyclerView.ViewHolder mo7442e(int i);\n\n /* renamed from: f */\n void mo7443f(int i, int i2);\n\n /* renamed from: g */\n void mo7444g(int i, int i2);\n\n /* renamed from: h */\n void mo7445h(int i, int i2);\n }", "void mo46242a(bmc bmc);", "public abstract void mo9809b(int i);", "public abstract int mo4307b(int i);", "public interface C3196it extends C3208jc {\n /* renamed from: a */\n void mo30275a(long j);\n\n /* renamed from: b */\n C3197iu mo30281b(long j);\n\n /* renamed from: b */\n boolean mo30282b();\n\n /* renamed from: c */\n byte mo30283c();\n\n /* renamed from: c */\n String mo30285c(long j);\n\n /* renamed from: d */\n void mo30290d(long j);\n\n /* renamed from: e */\n int mo30291e();\n\n /* renamed from: f */\n long mo30295f();\n}", "public interface C26438t {\n /* renamed from: b */\n void mo5959b(boolean z, String str, Bundle bundle);\n}", "C4932q5 mo19394a(byte[] bArr) throws zzfn;", "public interface C11922a {\n void bvR();\n }", "interface C3069a {\n @C0193h0\n /* renamed from: a */\n Bitmap mo12204a(int i, int i2, Config config);\n\n /* renamed from: a */\n void mo12205a(Bitmap bitmap);\n\n /* renamed from: a */\n void mo12206a(byte[] bArr);\n\n /* renamed from: a */\n void mo12207a(int[] iArr);\n\n /* renamed from: a */\n int[] mo12208a(int i);\n\n /* renamed from: b */\n byte[] mo12209b(int i);\n }", "C2451d mo3408a(C2457e c2457e);", "interface C1939a {\n /* renamed from: a */\n Bitmap mo1406a(Bitmap bitmap, float f);\n}", "public abstract void mo9810b(int i, int i2);", "void mo63039b(int i, int i2);", "public abstract void mo9798a(byte b);", "public abstract void mo12694b(C1085v vVar, int i);", "public interface C10330c {\n /* renamed from: a */\n C7562b<C10403b, C10328a> mo25041a();\n}", "public interface C24221b extends C28343z<C28318an> {\n /* renamed from: a */\n void mo62991a(int i);\n\n String aw_();\n\n /* renamed from: e */\n Aweme mo62993e();\n}", "void mo86a(C0163d c0163d);", "void mo4873a(C4718l c4718l);", "public interface C4932q5 extends C4994t5, Cloneable {\n /* renamed from: B */\n C4945r5 mo19056B();\n\n /* renamed from: F */\n C4945r5 mo19057F();\n\n /* renamed from: a */\n C4932q5 mo19393a(C4945r5 r5Var);\n\n /* renamed from: a */\n C4932q5 mo19394a(byte[] bArr) throws zzfn;\n\n /* renamed from: a */\n C4932q5 mo19395a(byte[] bArr, C5005u3 u3Var) throws zzfn;\n}", "public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}", "public interface C8326b {\n /* renamed from: a */\n C8325a mo21498a(String str);\n\n /* renamed from: a */\n void mo21499a(C8325a aVar);\n}", "public void mo1554b(ac acVar) {\n }" ]
[ "0.7191906", "0.6869366", "0.6690985", "0.668237", "0.664386", "0.66343516", "0.6594407", "0.65822035", "0.6572265", "0.6557151", "0.65321684", "0.6523202", "0.64994454", "0.6479987", "0.6474812", "0.6471467", "0.64623237", "0.6432783", "0.64172006", "0.641237", "0.64097464", "0.6387366", "0.6379635", "0.6372368", "0.6355606", "0.6327802", "0.63266397", "0.6322474", "0.62979144", "0.6295475", "0.6279578", "0.62711734", "0.62528306", "0.6249151", "0.62459743", "0.62452453", "0.6215353", "0.6209957", "0.6209802", "0.6202981", "0.620075", "0.6200712", "0.61968315", "0.619579", "0.61944973", "0.61895186", "0.6186978", "0.6181644", "0.61805695", "0.6172807", "0.6171709", "0.6169768", "0.6168794", "0.61687803", "0.6168", "0.61652344", "0.6152074", "0.61494625", "0.61429596", "0.61323744", "0.6119872", "0.61187464", "0.611616", "0.61090076", "0.6105572", "0.6101253", "0.60953605", "0.60928625", "0.60926104", "0.60921735", "0.6091104", "0.6087149", "0.60823643", "0.6079898", "0.6078352", "0.607697", "0.60769475", "0.60768974", "0.6068326", "0.6056591", "0.6050942", "0.60446745", "0.6040229", "0.603678", "0.6033718", "0.6030635", "0.6027147", "0.6026525", "0.60231775", "0.6021137", "0.6020307", "0.6020024", "0.6017518", "0.60168403", "0.60168064", "0.60152197", "0.60136855", "0.60108083", "0.60097665", "0.60030323", "0.5999636" ]
0.0
-1
$FF: renamed from: c () void
public void method_2197() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public static void c0() {\n\t}", "public void c() {\n }", "void mo80457c();", "void mo57278c();", "void mo5290b(C5102c c5102c);", "void mo5289a(C5102c c5102c);", "public static void c1() {\n\t}", "void mo17012c();", "void mo12638c();", "void mo67924c();", "void mo21072c();", "void mo72114c();", "void mo57277b();", "public abstract void mo70702a(C30989b c30989b);", "public abstract void mo53562a(C18796a c18796a);", "void mo28194a();", "void mo88524c();", "void mo80455b();", "void mo17021c();", "void mo41086b();", "public final void cpp() {\n }", "void mo41083a();", "void mo72113b();", "public static void c3() {\n\t}", "void mo119582b();", "public abstract void mo27385c();", "void mo28306a();", "void mo80452a();", "void mo86a(C0163d c0163d);", "public abstract int c();", "public abstract int c();", "void mo67923b();", "public void mo97906c() {\n }", "void mo1493c();", "public void mo1403c() {\n }", "void mo88523b();", "void mo28717a(zzc zzc);", "void mo54405a();", "void mo38026a();", "void mo13368a();", "public static void CC2_1() {\n\t}", "void mo98969a();", "void mo12634a();", "void mo22249a();", "void mo8712a(C9714a c9714a);", "public void mo56167c() {\n }", "void mo69874a();", "void mo21073d();", "void mo88521a();", "void mo84655a();", "public void mo6944a() {\n }", "public /* bridge */ /* synthetic */ void mo55096c() {\n super.mo55096c();\n }", "void mo57275a();", "void mo9693a();", "public void mo5099c() {\n }", "public abstract void mo27386d();", "public final void mo11687c() {\n }", "public void mo21825b() {\n }", "public void m23075a() {\n }", "public abstract int mo41077c();", "@Override\n\tpublic void ccc() {\n\t\t\n\t}", "void m1864a() {\r\n }", "void mo54435d();", "void mo67920a();", "void mo21074e();", "void mo119581a();", "void mo60892a();", "void mo56163g();", "void mo60893b();", "public static a c() {\n }", "void mo105476a();", "public void mo115190b() {\n }", "public abstract C mo29734a();", "void mo72111a();", "public void a(cvk paramcvk)\r\n/* 76: */ {\r\n/* 77: 95 */ c();\r\n/* 78: */ }", "public void func_70305_f() {}", "void mo37810a();", "void mo3193f();", "public void mo44053a() {\n }", "void mo1970b();", "public final /* bridge */ /* synthetic */ void mo43571c() {\n super.mo43571c();\n }", "void mo3194r();", "public abstract void mo70713b();", "public void mo97908d() {\n }", "public abstract void mo30696a();", "void mo12143a();", "void mo12637b();", "void mo4873a(C4718l c4718l);", "void m8368b();", "void mo17023d();", "public final void mo91715d() {\n }", "public void b() {\r\n }", "public int c()\r\n/* 74: */ {\r\n/* 75:78 */ return this.c;\r\n/* 76: */ }", "public void mo5097b() {\n }", "public void mo21779D() {\n }", "public void mo115188a() {\n }", "public abstract void mo6549b();", "void mo304a(C0366h c0366h);", "void mo1749a(C0288c cVar);", "void mo3311a();", "public abstract void mo42329d();" ]
[ "0.76791036", "0.76179284", "0.7522613", "0.7412385", "0.73603237", "0.73256433", "0.7264573", "0.71615005", "0.7146747", "0.7137986", "0.70685774", "0.70649755", "0.70573264", "0.7048773", "0.70322734", "0.7031232", "0.70249605", "0.7017386", "0.69845617", "0.69670725", "0.6945534", "0.6932042", "0.6908649", "0.69043314", "0.6901462", "0.68990105", "0.6894553", "0.68852013", "0.6860013", "0.6824629", "0.6824629", "0.6816274", "0.68145764", "0.6813835", "0.6812024", "0.6791053", "0.6790392", "0.67746013", "0.6758523", "0.67579967", "0.67316484", "0.6724151", "0.670351", "0.6701669", "0.6684049", "0.66717803", "0.66660124", "0.6658602", "0.6658368", "0.6652986", "0.66465354", "0.6632596", "0.6621108", "0.6606473", "0.65986484", "0.6592216", "0.6585343", "0.6581669", "0.6578778", "0.6577977", "0.6577755", "0.6569586", "0.6565567", "0.6554686", "0.6551451", "0.65486515", "0.653485", "0.65291953", "0.6527789", "0.6523631", "0.6519778", "0.65170455", "0.6509008", "0.6508713", "0.6504312", "0.64949036", "0.64942193", "0.64906967", "0.6483112", "0.6477813", "0.6476516", "0.6469512", "0.6465844", "0.6457574", "0.64520305", "0.64452475", "0.6438391", "0.64353776", "0.64303714", "0.6429201", "0.6427045", "0.6425864", "0.64252806", "0.6421531", "0.6420813", "0.64164597", "0.6413639", "0.6405197", "0.639979", "0.6394303", "0.6390879" ]
0.0
-1
$FF: renamed from: e () void
protected void method_2241() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n\tpublic void e() {\n\n\t}", "public void e() {\n }", "void event(Event e) throws Exception;", "@Override\n public void e(int i0, int i1) {\n\n }", "@Override\n\tpublic void einkaufen() {\n\t}", "@Override\n public void e(String TAG, String msg) {\n }", "public void mo2471e() {\n }", "void berechneFlaeche() {\n\t}", "public static void feec() {\n\t}", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "@Override\r\n\tpublic void onEvent(Object e) {\n\t}", "public void mo1405e() {\n }", "public void mo21780E() {\n }", "@Override\n public void b() {\n }", "public final void mo91720e() {\n super.mo91720e();\n }", "void mo21074e();", "public abstract void mo27386d();", "private final void i() {\n }", "@Override\n public void actionPerformed( final ActionEvent e ) {\n // NO OPERATION\n }", "private void m50366E() {\n }", "@Override\n\tpublic void a() {\n\t\t\n\t}", "@Override\n\tpublic void processEvent(Event e) {\n\n\t}", "public void furyo ()\t{\n }", "@Override\n\tpublic void b() {\n\n\t}", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "public void mo6944a() {\n }", "Event () {\n // Nothing to do here.\n }", "@Override\n\tpublic void actionPerformed(java.awt.event.ActionEvent e) {\n\n\t}", "@Override\r\n\tpublic void onEvent(Event arg0) {\n\r\n\t}", "@Override\n\tpublic void yürü() {\n\n\t}", "void m5771e() throws C0841b;", "@Override\r\n\t\t\tpublic void execute(LiftEvent e) {\n\t\t\t\t\r\n\t\t\t}", "@Override\r\n\t\t\tpublic void execute(LiftEvent e) {\n\t\t\t\t\r\n\t\t\t}", "public /* bridge */ /* synthetic */ void mo22963g(C7059Ec ec) {\n super.mo22963g(ec);\n }", "void bye();", "@Override\r\n\tpublic void performAction(Event e) {\n\r\n\t}", "public void mo97908d() {\n }", "public interface e {\n}", "public void m23075a() {\n }", "public abstract void mo42330e();", "public void compile(Emitter e)\n {\n throw new RuntimeException(\"Implement me!!!!!\");\n }", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "public void mo21779D() {\n }", "public abstract void mo70713b();", "public void o_()\r\n/* 533: */ {\r\n/* 534:539 */ this.e = true;\r\n/* 535: */ }", "@Override\n public void func_104112_b() {\n \n }", "void saySomething(String desc, MouseEvent e) {\n\t}", "@Override\r\n public void actionPerformed( ActionEvent e )\r\n {\n }", "public final void mo91715d() {\n }", "public void mo21825b() {\n }", "void mo56161e();", "@Override\n public void actionPerformed(ActionEvent e) {\n throw new UnsupportedOperationException(\"Not supported yet.\"); //To change body of generated methods, choose Tools | Templates.\n }", "public byte e()\r\n/* 84: */ {\r\n/* 85:86 */ return this.e;\r\n/* 86: */ }", "public void mo44053a() {\n }", "public void g() {\n }", "public void b() {\r\n }", "@Override\r\n public void actionPerformed(ActionEvent e) {\r\n throw new UnsupportedOperationException(\"Not supported yet.\"); //To change body of generated methods, choose Tools | Templates.\r\n }", "public void mo21879u() {\n }", "public void mo21781F() {\n }", "public abstract void mo27464a();", "@Override\r\n\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t\t\r\n\t\t}", "public abstract void mo56925d();", "@Override\n\t\tpublic void actionPerformed(ActionEvent e) {\n\t\t}", "public void mo38117a() {\n }", "@Override\n\tpublic void emprestimo() {\n\n\t}", "public void h() {\n }", "public void b(Object obj) {\n e();\n }", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\t\t\n\t}", "protected void h() {}", "public void e() {\n v.b bVar = this.i;\n if (bVar != null) {\n this.f.a(bVar);\n }\n a1 a1Var = this.g;\n if (a1Var != null) {\n a1Var.a();\n }\n this.g = null;\n }", "public void mo9137b() {\n }", "void mo43357a(C16726e eVar) throws RemoteException;", "@Override\n\tpublic void function() {\n\t\t\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e)\n\t{\n\t\t\n\t}", "void element() {}", "public void mo5248a() {\n }", "void m5770d() throws C0841b;", "public void mo115188a() {\n }", "void m5769c() throws C0841b;", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\n\t}", "@Override\n\tpublic void actionPerformed(ActionEvent e) {\n\n\t}" ]
[ "0.8312422", "0.8264417", "0.72700495", "0.7247195", "0.69755065", "0.69696814", "0.6887521", "0.6826573", "0.67847836", "0.678288", "0.6774456", "0.67203873", "0.6706484", "0.6700481", "0.66787916", "0.66538566", "0.6599632", "0.65687495", "0.65671915", "0.65503955", "0.6527807", "0.6522765", "0.65134937", "0.65119123", "0.65116996", "0.65062594", "0.65056515", "0.6498983", "0.6497594", "0.64974135", "0.64855856", "0.64737356", "0.64737356", "0.6472198", "0.6466342", "0.64644665", "0.6463559", "0.645089", "0.64474785", "0.6447299", "0.64355326", "0.6433844", "0.64254445", "0.64144564", "0.64134467", "0.6404883", "0.6399569", "0.6371175", "0.6368224", "0.63622636", "0.63553596", "0.63484377", "0.6338535", "0.63323754", "0.63280857", "0.63248765", "0.63168925", "0.63146144", "0.62982196", "0.6294951", "0.6293647", "0.6292211", "0.629187", "0.6276817", "0.62748456", "0.6259582", "0.6255312", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62524325", "0.62474126", "0.6246874", "0.62411565", "0.62395567", "0.6234144", "0.6232839", "0.62322843", "0.6231292", "0.6226427", "0.62251997", "0.62242866", "0.621775", "0.621775", "0.621775" ]
0.0
-1
$FF: renamed from: i () void
private void method_2242() { this.field_1824.method_6863(0); this.field_1824.method_6861(false); this.field_1824.method_6859(0); this.field_1824.method_6857(false); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "private final void i() {\n }", "public final void mo91727g(int i) {\n }", "void mo88773a(int i);", "void mo66998a(int i);", "void mo26876a(int i);", "void mo1747a(int i);", "void mo54406a(int i);", "public final void mo91724f(int i) {\n }", "void mo1753b(int i);", "public void mo5332a(int i) {\n }", "public abstract void mo4376b(int i);", "public abstract void mo9809b(int i);", "public void mo44231a(int i) {\n }", "void mo17022c(int i);", "void mo1933b(int i);", "void mo1761g(int i);", "public final void mo5394iy(int i) {\n }", "void mo37668e(int i);", "void mo54437e(int i);", "void mo27576a(int i);", "void m15858a(int i);", "void mo1494c(int i);", "void mo17020b(int i);", "void mo17007a(int i);", "public void mo3350a(int i) {\n }", "void mo38565a(int i);", "void mo1485a(int i);", "void mo122221a(int i);", "void mo54447l(int i);", "public abstract void mo9734b(int i);", "void mo1754c(int i);", "void mo6247nm(int i);", "void mo17016a(int i);", "void mo3767a(int i);", "void mo1755d(int i);", "public abstract void mo4377b(int i, int i2);", "void mo54436d(int i);", "void mo63039b(int i, int i2);", "public final void mo91947k(int i) {\n }", "public abstract void mo2156b(int i);", "void mo1491b(int i);", "public abstract void mo4386e(int i, int i2);", "void mo3796b(int i);", "void mo62991a(int i);", "public abstract void mo4385d(int i);", "public abstract void mo9733a(int i);", "void mo54452q(int i);", "@Override\n\tpublic void i2() {\n\t\t\n\t}", "public abstract void mo9814c(int i);", "void mo7304b(int i, int i2);", "public abstract int mo4307b(int i);", "public abstract void mo9799a(int i);", "public static void bi() {\n\t}", "void mo13163e(int i);", "public abstract void mo9810b(int i, int i2);", "public abstract C14407a mo11608b(int i);", "void m(int i) {\r\n\t}", "void mo23327tY(int i);", "public abstract int mo12581RU(int i);", "public abstract void mo4361a(int i);", "void mo85a(int i);", "void mo17008a(int i, int i2);", "void mo32046rn(int i);", "void mo54407a(int i, int i2);", "public abstract int mo12582RV(int i);", "C3579d mo19710g(int i) throws IOException;", "void mo6888a(int i);", "void mo34684de(int i, int i2);", "private final void m57536a(int i) {\n m57542d(i);\n }", "public abstract void mo102900a(int i, int i2);", "void mo7301a(int i, int i2);", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "void mo7438a(int i, int i2);", "void mo1763h(int i);", "void mo54424b(int i);", "public void mo21784I() {\n }", "void mo17017a(int i, int i2);", "void mo63037a(int i, int i2);", "void mo54446k(int i);", "public void a(i iVar) {\n }", "public abstract void mo2140a(int i);", "public abstract C14407a mo11604a(int i);", "public abstract C14407a mo11609c(int i);", "public abstract void mo9800a(int i, int i2);", "void mo4103b(int i, int i2);", "void mo66999a(int i, int i2);", "public void mo9253f(int i, int i2) {\n }", "void mo7443f(int i, int i2);", "void mo28890b(int i) throws zzlm;", "void mo4102a(int i, int i2);", "public abstract void mo4381c(int i, int i2);", "void mo7306c(int i, int i2);", "public abstract void mo4362a(int i, int i2);", "private final void m57542d(int i) {\n this.f47569e.m63095a(new C15337b(i, true));\n }", "public void mo115203b(int i, int i2) {\n }", "public void mo25766a(int i) {\n mo73989c(i);\n }", "public abstract AbstractC5666g mo39572a(int i);", "public final void mo74760a(C29296g gVar, int i) {\n }", "void mo22044oA(int i);", "void mo25956a(int i);", "void mo56156a(int i, int i2);" ]
[ "0.84918326", "0.77806765", "0.7631778", "0.75177246", "0.75145715", "0.7512507", "0.7500242", "0.74565804", "0.7454645", "0.7445058", "0.7442278", "0.7419122", "0.7418939", "0.7418635", "0.74072444", "0.73946065", "0.7371105", "0.7339137", "0.73350537", "0.7308839", "0.7294326", "0.7290188", "0.72458357", "0.72341186", "0.7226571", "0.72139215", "0.7210472", "0.7205947", "0.7204102", "0.7196586", "0.71904564", "0.7183531", "0.71596193", "0.7158801", "0.71312773", "0.7093275", "0.7092605", "0.7088673", "0.7086544", "0.70848525", "0.7084534", "0.70781696", "0.7077934", "0.7070058", "0.7063823", "0.70358646", "0.70167637", "0.6993784", "0.6993331", "0.69914687", "0.698948", "0.6986099", "0.6983721", "0.6975699", "0.6947913", "0.69440466", "0.6940851", "0.6934203", "0.6922345", "0.6919815", "0.69189584", "0.69108355", "0.68963265", "0.68841696", "0.6881692", "0.6881169", "0.68577427", "0.6852984", "0.6850153", "0.6840769", "0.683792", "0.68187237", "0.68153346", "0.68047965", "0.6802143", "0.6792605", "0.67886204", "0.67870283", "0.6781289", "0.6780919", "0.6780111", "0.6779459", "0.6774893", "0.67720103", "0.6769652", "0.67619866", "0.67594874", "0.6751397", "0.67460316", "0.67428505", "0.67363095", "0.6736301", "0.6731495", "0.672884", "0.67256397", "0.67094773", "0.6701526", "0.6693045", "0.66873497", "0.66831094", "0.6672433" ]
0.0
-1
$FF: renamed from: k () boolean
public boolean method_2243() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public boolean k_()\r\n/* 450: */ {\r\n/* 451:464 */ return false;\r\n/* 452: */ }", "boolean defined(K k);", "public abstract void mo32005dK(boolean z);", "public void setK(boolean k) {\n\tthis.k = k;\n }", "public boolean hasK() {\n return resultCase_ == 3;\n }", "public boolean hasK() {\n return resultCase_ == 3;\n }", "public boolean a()\r\n/* 598: */ {\r\n/* 599:597 */ return this.k;\r\n/* 600: */ }", "public boolean k(android.view.View r33, boolean r34) {\n /*\n // Method dump skipped, instructions count: 2908\n */\n throw new UnsupportedOperationException(\"Method not decompiled: defpackage.C5887z9.k(android.view.View, boolean):boolean\");\n }", "public abstract boolean zzbek();", "boolean mo203k();", "public void ak(boolean z) {\n }", "public boolean hasKv() {\n return resultCase_ == 2;\n }", "public void a(boolean paramBoolean)\r\n/* 593: */ {\r\n/* 594:593 */ this.k = paramBoolean;\r\n/* 595: */ }", "boolean getKeyBox();", "boolean isKOd();", "public boolean hasKv() {\n return resultCase_ == 2;\n }", "public abstract boolean mo66253b();", "protected boolean func_70814_o() { return true; }", "boolean requiresExpression(int k);", "public boolean checkKey(char k) { \r\n \t\tif (keys.length >= k) {\r\n \t\t\treturn keys[k];\r\n \t\t}\r\n \t\treturn false;\r\n \t}", "private void kk12() {\n\n\t}", "void mo1492b(boolean z);", "org.apache.xmlbeans.XmlBoolean xgetKeyWheel();", "void mo21069a(boolean z);", "public static boolean bitTester(int x, int k) {\n\t\tx = x >> k;\n\t\treturn (x & 1) == 1; // x's kth bit\n\t}", "boolean hasKey();", "boolean hasKey();", "boolean hasKey();", "boolean hasKey();", "boolean hasKey();", "void mo1488a(boolean z);", "void mo26249mh(boolean z);", "void mo98208a(boolean z);", "public boolean c()\r\n/* 36: */ {\r\n/* 37:51 */ return false;\r\n/* 38: */ }", "void mo197b(boolean z);", "public void func_70295_k_() {}", "boolean hasCompoundKey();", "void mo99838a(boolean z);", "boolean isSetKeyWheel();", "public boolean hasKdKelas() {\n return fieldSetFlags()[0];\n }", "public abstract boolean mo36211n();", "public abstract boolean mo9234ar();", "org.apache.xmlbeans.XmlBoolean xgetKeyBox();", "public static boolean isKeyDown(int k) {\n switch (k) {\n case KeyEvent.VK_UP:\n case KeyEvent.VK_W:\n return keyUp;\n case KeyEvent.VK_DOWN:\n case KeyEvent.VK_S:\n return keyDown;\n case KeyEvent.VK_LEFT:\n case KeyEvent.VK_A:\n return keyLeft;\n case KeyEvent.VK_RIGHT:\n case KeyEvent.VK_D:\n return keyRight;\n case KeyEvent.VK_SPACE:\n return keyShoot;\n default:\n return false;\n }\n }", "void mo6661a(boolean z);", "public abstract void mo9254f(boolean z);", "boolean hasCdkey();", "public boolean i()\r\n/* 46: */ {\r\n/* 47:50 */ return true;\r\n/* 48: */ }", "void mo64153a(boolean z);", "void mo21071b(boolean z);", "public boolean isKing(){return this.king;}", "boolean internal();", "boolean getKeyWheel();", "public boolean getBoolean(String name)\n/* */ {\n/* 845 */ return getBoolean(name, false);\n/* */ }", "boolean isSetKeyBox();", "boolean getB26();", "public boolean contains(int k) {\n // YOUR CODE HERE\n return true;\n }", "public abstract void mo32006dL(boolean z);", "public boolean hasKdMk() {\n return fieldSetFlags()[7];\n }", "public boolean mo33819k() {\n return false;\n }", "public boolean mo33819k() {\n return false;\n }", "void mo22049es(boolean z);", "boolean mo1292a() {\n return true;\n }", "private int getBit(int value, int k) {\r\n\t\treturn (value >> k) & 1;\r\n\t}", "public boolean mo23269K() {\n return ((Boolean) this.f13965a.mo23249a(C7196pb.f13755Sc)).booleanValue();\n }", "void mo12636a(boolean z);", "void mo3305a(boolean z);", "public final boolean m2276k() {\n return this.f2952a == ValueType.object;\n }", "public boolean DEBUG_containsAtALL(int k) {\r\n Node curr = head.get();\r\n \r\n while (curr != null) {\r\n \r\n if (curr.key == k) {\r\n //s = curr.state;\r\n \r\n //if (s != 3 && s != 1) {\r\n return true;\r\n //}\r\n }\r\n curr = curr.next;\r\n }\r\n return false;\r\n }", "boolean getB27();", "public abstract boolean mo9230aE();", "public boolean kosong() {\r\n return ukuran == 0;\r\n }", "boolean hasGcj02();", "public boolean mo879k() {\n return (this.f631z & 2) == 2;\n }", "boolean mo44966c();", "private void test(int k) {\n if (state[left(k)] != State.EATING && state[k] == State.HUNGRY\n && state[right(k)] != State.EATING) {\n state[k] = State.EATING;\n }\n }", "void mo54420a(boolean z, boolean z2);", "public boolean q_()\r\n/* 178: */ {\r\n/* 179:203 */ return false;\r\n/* 180: */ }", "private boolean isTrue(final Variable key) {\n return data.containsKey(key) && Boolean.TRUE.equals(data.get(key));\n }", "public boolean contains (int k) {\n\t\treturn contains[k];\n\t}", "public abstract boolean mo9737c();", "boolean hasC();", "boolean mo54431c();", "boolean getBoolean(String key) throws KeyValueStoreException;", "boolean mo30282b();", "public boolean a(aog ☃) {\r\n/* 179 */ if (!☃.dK()) {\r\n/* 180 */ return false;\r\n/* */ }\r\n/* 182 */ if ((☃.bJ()).B) {\r\n/* 183 */ ☃.a(this);\r\n/* */ }", "@Override // com.tapjoy.internal.fz\n public final boolean a() {\n return super.a() && !hk.c();\n }", "boolean mo44967d();", "private final boolean isTrue(final Variable key) {\n return data.containsKey(key) && Boolean.TRUE.equals(data.get(key));\n }", "public abstract boolean mo9735b();", "boolean mo1293b() {\n return true;\n }", "boolean mo2803a(boolean z);", "@Test\n\tpublic void test_returnBooleanFoo_true() {\n\n\t}", "boolean mo54429b();", "boolean mo1496d();", "@Override\r\n\tpublic boolean CXT_containsKey(String jsk)\r\n\t{\n\t\treturn false;\r\n\t}", "public boolean ci() {\n/* 84 */ return true;\n/* */ }", "protected boolean func_70041_e_() { return false; }", "private boolean isLava() {\n/* 317 */ return this.isLava;\n/* */ }", "boolean mo72115d();", "public boolean tom();" ]
[ "0.76890653", "0.72395194", "0.7196108", "0.7122633", "0.6897799", "0.6837367", "0.6819478", "0.66667485", "0.6616237", "0.64112025", "0.6373077", "0.63582706", "0.6355418", "0.6299531", "0.6265771", "0.62436527", "0.6241704", "0.6211292", "0.6201307", "0.616776", "0.6165375", "0.6147567", "0.6121889", "0.61099863", "0.61047715", "0.6099957", "0.6099957", "0.6099957", "0.6099957", "0.6099957", "0.60969055", "0.6077519", "0.60768056", "0.60570574", "0.6049848", "0.60492915", "0.6046807", "0.6046334", "0.6043892", "0.60270894", "0.6018072", "0.60140586", "0.60031044", "0.5971813", "0.59717834", "0.59389395", "0.5928952", "0.5916219", "0.59140587", "0.591214", "0.59110254", "0.5908793", "0.59085757", "0.5904175", "0.59008986", "0.58977747", "0.5897253", "0.5888073", "0.58857244", "0.58854395", "0.58854395", "0.5885037", "0.58727515", "0.58496064", "0.58495533", "0.5848279", "0.5843925", "0.582521", "0.58225477", "0.5812301", "0.5812089", "0.5805937", "0.5801087", "0.5795623", "0.5795164", "0.57891357", "0.5786823", "0.57821745", "0.57810557", "0.5777646", "0.577159", "0.5764434", "0.57631975", "0.57603306", "0.5756774", "0.57540345", "0.57530195", "0.57509434", "0.5748841", "0.57449156", "0.5740638", "0.5725963", "0.5725596", "0.57246506", "0.5721676", "0.57127345", "0.5704836", "0.57032865", "0.5691476", "0.5690665", "0.5688913" ]
0.0
-1
$FF: renamed from: f () void
public void method_2046() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void func_70305_f() {}", "public void f() {\n }", "public void f() {\n }", "@Override\n public int f() {\n return 0;\n }", "void f1() {\r\n\t}", "@Override\n\tpublic void f1() {\n\n\t}", "@Override\n\tpublic void f2() {\n\t\t\n\t}", "void testMethod() {\n f();\n }", "void mo3193f();", "public void f() {\n Message q_ = q_();\n e.c().a(new f(255, a(q_.toByteArray())), getClass().getSimpleName(), i().a(), q_);\n }", "void mo84656a(float f);", "void mo21075f();", "public void f() {\n this.f25459e.J();\n }", "public abstract int mo123247f();", "public void furyo ()\t{\n }", "void mo54440f();", "public abstract int mo9741f();", "public byte f()\r\n/* 89: */ {\r\n/* 90:90 */ return this.f;\r\n/* 91: */ }", "void mo67923b();", "public abstract long f();", "public interface f {\n void a();\n}", "public abstract int f(int i2);", "void mo57277b();", "void mo80455b();", "void mo72112a(float f);", "public abstract void mo42330e();", "void b();", "public void g() {\n <caret>f(null, null);\n }", "void mo56155a(float f);", "public abstract void mo42331g();", "void berechneFlaeche() {\n\t}", "void mo72113b();", "void mo119582b();", "static void feladat9() {\n\t}", "void mo28194a();", "public void t();", "public void mo21781F() {\n }", "public final void mo8765a(float f) {\n }", "void mo41086b();", "void mo41083a();", "void mo9694a(float f, float f2);", "void mo88523b();", "@Override\n\tpublic void function() {\n\t\t\n\t}", "public void mo42331g() {\n mo42335f();\n }", "void mo80452a();", "public abstract void mo42329d();", "public void foo() {\r\n\t}", "public abstract void mo70713b();", "public void b() {\r\n }", "void mo28306a();", "public abstract void mo27386d();", "public void g() {\n }", "@Override\n\tpublic void visit(Function arg0) {\n\t\t\n\t}", "void mo69874a();", "void mo54405a();", "static void feladat4() {\n\t}", "public static void func() {\n }", "private void m50367F() {\n }", "@Override\n public void visitFunction(Function function) {\n }", "@Override\n public void func_104112_b() {\n \n }", "public interface AbstractC17368c {\n /* renamed from: a */\n void mo84656a(float f);\n }", "public void b() {\n }", "public void b() {\n }", "void mo56161e();", "void mo67920a();", "void mo22249a();", "void mo84655a();", "public void mo1406f() {\n }", "public amj p()\r\n/* 543: */ {\r\n/* 544:583 */ return this.f;\r\n/* 545: */ }", "void mo72111a();", "public static void feec() {\n\t}", "public int F()\r\n/* 24: */ {\r\n/* 25: 39 */ return aqt.a(0.5D, 1.0D);\r\n/* 26: */ }", "void fun();", "void fun();", "void mo13368a();", "public abstract void mo45765b();", "public abstract void afvuren();", "public void a() {\r\n }", "static void feladat7() {\n\t}", "void mo9693a();", "public void m51745d() {\n this.f42403b.a();\n }", "void mo98969a();", "public abstract void mo102899a();", "public abstract void mo3994a();", "void mo196b(float f) throws RemoteException;", "public Fun_yet_extremely_useless()\n {\n\n }", "public abstract void mo30696a();", "public abstract void mo35054b();", "public abstract void mo6549b();", "static void feladat5() {\n\t}", "static void feladat3() {\n\t}", "@Override\n\tpublic void visit(Function arg0) {\n\n\t}", "public void mo6944a() {\n }", "void mo38026a();", "void mo21073d();", "void mo9704b(float f, float f2, int i);", "void mo119581a();", "void mo37810a();", "static void feladat10() {\n\t}", "public void a() {\n }", "public void a() {\n }" ]
[ "0.8134333", "0.80543995", "0.8033524", "0.76442426", "0.7462097", "0.7073271", "0.7064105", "0.690873", "0.68817496", "0.6876525", "0.68603873", "0.6848948", "0.6845149", "0.67928916", "0.6765434", "0.67166066", "0.666712", "0.6617843", "0.6610579", "0.6603914", "0.65898085", "0.6589486", "0.65589535", "0.6513115", "0.6479514", "0.64713615", "0.6468997", "0.646159", "0.64579636", "0.6456077", "0.64504564", "0.6428972", "0.64169556", "0.64082426", "0.64022523", "0.6394493", "0.6392837", "0.6386536", "0.6384613", "0.63813573", "0.6371735", "0.63693297", "0.6362958", "0.6348112", "0.6341992", "0.63360274", "0.63279486", "0.63252014", "0.6324033", "0.6311901", "0.63026786", "0.629782", "0.62945604", "0.62944716", "0.62930894", "0.6283447", "0.6281591", "0.6275131", "0.62694734", "0.62632173", "0.6248491", "0.6247392", "0.6247392", "0.6245181", "0.6243336", "0.62411875", "0.623796", "0.6235685", "0.62355936", "0.6235458", "0.62344307", "0.62339646", "0.6214", "0.6214", "0.6190069", "0.61866194", "0.61833656", "0.61827797", "0.61744595", "0.6169671", "0.616807", "0.61643", "0.6158174", "0.6151671", "0.6151459", "0.6145472", "0.6142344", "0.61396605", "0.6134533", "0.6126942", "0.61255145", "0.6123562", "0.6120639", "0.6117485", "0.6116747", "0.61158943", "0.61144286", "0.6108269", "0.61042833", "0.61037844", "0.61037844" ]
0.0
-1
$FF: renamed from: g () void
protected void method_2145() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void g() {\n }", "public int g()\r\n/* 173: */ {\r\n/* 174:198 */ return 0;\r\n/* 175: */ }", "public abstract long g();", "void mo56163g();", "public void g() {\n this.f25459e.Q();\n }", "public boolean g()\r\n/* 94: */ {\r\n/* 95:94 */ return this.g;\r\n/* 96: */ }", "public int g()\r\n/* 601: */ {\r\n/* 602:645 */ return 0;\r\n/* 603: */ }", "void mo21076g();", "public int g()\r\n {\r\n return 1;\r\n }", "public void g() {\n <caret>f(null, null);\n }", "void mo57277b();", "void mo41086b();", "public void gored() {\n\t\t\n\t}", "public abstract void mo42331g();", "public final h.c.b<java.lang.Object> g() {\n /*\n r2 = this;\n h.c.b<java.lang.Object> r0 = r2.f15786a\n if (r0 == 0) goto L_0x0005\n goto L_0x001d\n L_0x0005:\n h.c.e r0 = r2.b()\n h.c.c$b r1 = h.c.c.f14536c\n h.c.e$b r0 = r0.get(r1)\n h.c.c r0 = (h.c.c) r0\n if (r0 == 0) goto L_0x001a\n h.c.b r0 = r0.c(r2)\n if (r0 == 0) goto L_0x001a\n goto L_0x001b\n L_0x001a:\n r0 = r2\n L_0x001b:\n r2.f15786a = r0\n L_0x001d:\n return r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: kotlin.coroutines.jvm.internal.ContinuationImpl.g():h.c.b\");\n }", "void mo119582b();", "void mo67923b();", "void mo28194a();", "public void stg() {\n\n\t}", "public void b(gy ☃) {}\r\n/* */ \r\n/* */ \r\n/* */ \r\n/* */ public void a(gy ☃) {}", "void mo80455b();", "void mo69874a();", "default int foo (){\n System.out.println(\"this is bytecode G1.foo()\");\n return -1;\n }", "void mo72113b();", "void go() {\n }", "void mo98970a(C29296g gVar);", "private final void i() {\n }", "public void func_70305_f() {}", "public final void mo74759a(C29296g gVar) {\n }", "void mo21074e();", "void mo41083a();", "public void mo21782G() {\n }", "void mo98971a(C29296g gVar, int i);", "public void t();", "void mo57278c();", "void mo28306a();", "void mo54405a();", "void mo88523b();", "public void h() {\n }", "protected void h() {}", "public abstract long g(int i2);", "public final void mo74763d(C29296g gVar) {\n }", "public void j() {\n }", "void mo80452a();", "void mo80457c();", "void mo84655a();", "public void furyo ()\t{\n }", "public void f() {\n }", "void mo28307a(zzgd zzgd);", "void mo67920a();", "void mo22249a();", "@Override\n\tpublic void visit(Function arg0) {\n\t\t\n\t}", "public abstract void mo70713b();", "private static void g() {\n h h10 = q;\n synchronized (h10) {\n h10.f();\n Object object = h10.e();\n object = object.iterator();\n boolean bl2;\n while (bl2 = object.hasNext()) {\n Object object2 = object.next();\n object2 = (g)object2;\n Object object3 = ((g)object2).getName();\n object3 = i.h.d.j((String)object3);\n ((g)object2).h((i.h.c)object3);\n }\n return;\n }\n }", "void mo56161e();", "public void f() {\n }", "public void b() {\r\n }", "void mo119581a();", "public void e() {\n v.b bVar = this.i;\n if (bVar != null) {\n this.f.a(bVar);\n }\n a1 a1Var = this.g;\n if (a1Var != null) {\n a1Var.a();\n }\n this.g = null;\n }", "void mo38026a();", "void b();", "void mo57275a();", "void mo54435d();", "interface G1 {\n default int foo (){ // should be intercepted by peer\n System.out.println(\"this is bytecode G1.foo()\");\n return -1;\n }\n }", "void mo21073d();", "void mo98969a();", "void mo13368a();", "public void n() {\n this.f80658c.a(new f() {\n public void a(Object obj, boolean z) {\n p unused = m.this.f80658c = (p) obj;\n }\n }, \"__ag_of\");\n }", "public int b()\r\n/* 45: */ {\r\n/* 46: 58 */ g();\r\n/* 47: */ \r\n/* 48: 60 */ return super.b();\r\n/* 49: */ }", "public abstract void mo27386d();", "@Override\n public void b() {\n }", "public void mo6944a() {\n }", "public final void mo91727g(int i) {\n }", "private final zzgy zzgb() {\n }", "public abstract int mo9742g();", "void mo9693a();", "private void g()\r\n/* 30: */ {\r\n/* 31: 40 */ if (this.n) {\r\n/* 32: 41 */ return;\r\n/* 33: */ }\r\n/* 34: 45 */ if (this.l != null)\r\n/* 35: */ {\r\n/* 36: 47 */ if (this.f != null) {\r\n/* 37: 48 */ c();\r\n/* 38: */ }\r\n/* 39: 51 */ cuj.a(super.b(), this.l);\r\n/* 40: 52 */ this.n = true;\r\n/* 41: */ }\r\n/* 42: */ }", "void mo60892a();", "public void b() {\n }", "public void b() {\n }", "void mo72114c();", "public abstract void mo6549b();", "@Override\n public int f() {\n return 0;\n }", "void mo1761g(int i);", "void mo3193f();", "public void g() {\n this.f29279g.sendEmptyMessageDelayed(10, 1000);\n }", "void mo60893b();", "void mo105476a();", "void mo12634a();", "void mo67924c();", "public interface g {\n void a(int i, String str, boolean z);\n\n boolean a();\n\n void b();\n}", "void mo72111a();", "@Override\n\tpublic void visit(Function arg0) {\n\n\t}", "void mo88521a();", "void mo54440f();", "private void ss(){\n }", "void mo21075f();", "void m1864a() {\r\n }", "void m8368b();", "@Override\n\tpublic void b() {\n\n\t}", "@Override\n public void func_104112_b() {\n \n }" ]
[ "0.8236348", "0.7129124", "0.69351554", "0.688318", "0.6844494", "0.68359816", "0.6828114", "0.6807874", "0.6786692", "0.6743869", "0.6729092", "0.6704614", "0.6655458", "0.6607342", "0.6575535", "0.65644544", "0.6563656", "0.6560206", "0.6543619", "0.6537801", "0.65315974", "0.6489792", "0.64844894", "0.64741427", "0.64677525", "0.6442474", "0.64241624", "0.6418108", "0.6400195", "0.63829684", "0.63821805", "0.6379684", "0.63786405", "0.6371899", "0.63602436", "0.63488966", "0.63487303", "0.6344133", "0.6334089", "0.6324284", "0.6318571", "0.6314076", "0.6311959", "0.6286592", "0.6285087", "0.6277036", "0.62745464", "0.6274289", "0.6271274", "0.6266547", "0.6259787", "0.6252483", "0.62505776", "0.6249804", "0.62441516", "0.6236524", "0.6226316", "0.6217608", "0.62110263", "0.6210569", "0.6206597", "0.6205273", "0.62052697", "0.62006414", "0.6190063", "0.618666", "0.6180852", "0.6174477", "0.61665887", "0.6164586", "0.6163863", "0.61581486", "0.614687", "0.61359614", "0.6128086", "0.61265135", "0.612388", "0.6120768", "0.6109223", "0.6109223", "0.60980207", "0.60977536", "0.6093936", "0.60929507", "0.6090173", "0.60868686", "0.608081", "0.60796237", "0.6075073", "0.60745597", "0.6074146", "0.60738343", "0.6064995", "0.6053758", "0.6049303", "0.60386074", "0.6035149", "0.6034773", "0.6027844", "0.60253423", "0.6025315" ]
0.0
-1
$FF: renamed from: a (int, int, int, aji) boolean
public boolean method_2066(int var1, int var2, int var3, aji var4) { class_1050 var10000 = new class_1050; var10000.method_5952(var1, var2, var3, var4); class_1050 var5 = var10000; return this.field_1864.contains(var5); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo6661a(boolean z);", "void mo64153a(boolean z);", "void mo99838a(boolean z);", "void mo21069a(boolean z);", "void mo54415a(int i, boolean z);", "void mo13374a(boolean z, int i, int i2);", "void mo98208a(boolean z);", "void mo1488a(boolean z);", "void mo12636a(boolean z);", "void mo54420a(boolean z, boolean z2);", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "public abstract boolean mo43853a(long j);", "void mo3305a(boolean z);", "public boolean b(int paramInt, amj paramamj)\r\n/* 578: */ {\r\n/* 579:621 */ return true;\r\n/* 580: */ }", "public abstract void mo9806a(int i, boolean z);", "void mo28742b(boolean z, int i);", "void mo28309a(boolean z, int i);", "void mo9701a(boolean z);", "void mo13377a(boolean z, C15943j c15943j);", "abstract void mo956a(boolean z);", "public abstract void mo4368a(int i, boolean z);", "boolean mo2803a(boolean z);", "boolean mo38970a();", "void mo21071b(boolean z);", "void mo22049es(boolean z);", "void mo1492b(boolean z);", "public abstract boolean a();", "protected abstract boolean a(axz paramaxz, long paramLong, int paramInt1, int paramInt2, double paramDouble1, double paramDouble2, double paramDouble3, double paramDouble4, double paramDouble5, BitSet paramBitSet);", "public abstract boolean mo66253b();", "void mo197b(boolean z);", "public abstract boolean a(e parame, b paramb, int paramInt1, int paramInt2);", "void mo13369a(int i, int i2, int i3, boolean z);", "public abstract boolean mo9234ar();", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public abstract void mo9254f(boolean z);", "boolean mo25262a(int i);", "public boolean a(amj paramamj)\r\n/* 268: */ {\r\n/* 269:293 */ if ((paramamj == null) || (paramamj.b == 0) || (paramamj.b() == null)) {\r\n/* 270:294 */ return false;\r\n/* 271: */ }\r\n/* 272: */ try\r\n/* 273: */ {\r\n/* 274:298 */ if (!paramamj.g())\r\n/* 275: */ {\r\n/* 276: */ do\r\n/* 277: */ {\r\n/* 278:301 */ i = paramamj.b;\r\n/* 279:302 */ paramamj.b = e(paramamj);\r\n/* 280:303 */ } while ((paramamj.b > 0) && (paramamj.b < i));\r\n/* 281:304 */ if ((paramamj.b == i) && (this.d.by.d))\r\n/* 282: */ {\r\n/* 283:306 */ paramamj.b = 0;\r\n/* 284:307 */ return true;\r\n/* 285: */ }\r\n/* 286:309 */ return paramamj.b < i;\r\n/* 287: */ }\r\n/* 288:312 */ int i = j();\r\n/* 289:313 */ if (i >= 0)\r\n/* 290: */ {\r\n/* 291:314 */ this.a[i] = amj.b(paramamj);\r\n/* 292:315 */ this.a[i].c = 5;\r\n/* 293:316 */ paramamj.b = 0;\r\n/* 294:317 */ return true;\r\n/* 295: */ }\r\n/* 296:318 */ if (this.d.by.d)\r\n/* 297: */ {\r\n/* 298:320 */ paramamj.b = 0;\r\n/* 299:321 */ return true;\r\n/* 300: */ }\r\n/* 301:323 */ return false;\r\n/* 302: */ }\r\n/* 303: */ catch (Throwable localThrowable)\r\n/* 304: */ {\r\n/* 305:325 */ b localb = b.a(localThrowable, \"Adding item to inventory\");\r\n/* 306:326 */ j localj = localb.a(\"Item being added\");\r\n/* 307: */ \r\n/* 308:328 */ localj.a(\"Item ID\", Integer.valueOf(alq.b(paramamj.b())));\r\n/* 309:329 */ localj.a(\"Item data\", Integer.valueOf(paramamj.i()));\r\n/* 310:330 */ localj.a(\"Item name\", new ahc(this, paramamj));\r\n/* 311: */ \r\n/* 312: */ \r\n/* 313: */ \r\n/* 314: */ \r\n/* 315: */ \r\n/* 316: */ \r\n/* 317:337 */ throw new u(localb);\r\n/* 318: */ }\r\n/* 319: */ }", "public boolean a(World paramaqu, BlockPosition paramdt, Block parambec, boolean paramBoolean)\r\n/* 67: */ {\r\n/* 68: 83 */ return true;\r\n/* 69: */ }", "boolean mo34114a();", "public boolean a(long j) {\n return false;\n }", "public abstract void mo32006dL(boolean z);", "boolean mo30282b();", "public final boolean func_boolean_a(int var1, int var2) {\n if (this.func_boolean_b(var1, var2)) {\n return true;\n } else if (var2 != 53 && var1 != 8) {\n if (var2 == -8) {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)0);\n return true;\n } else {\n return true;\n }\n } else {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)1);\n return true;\n }\n }", "public abstract boolean mo9230aE();", "public boolean b(alq paramalq)\r\n/* 259: */ {\r\n/* 260:278 */ int i = c(paramalq);\r\n/* 261:279 */ if (i < 0) {\r\n/* 262:280 */ return false;\r\n/* 263: */ }\r\n/* 264:283 */ return true;\r\n/* 265: */ }", "boolean booleanOf();", "boolean mo23707a();", "boolean mo54429b();", "boolean mo1969a();", "private boolean m223a() {\n if (!at.d(this.f82006a)) {\n if (at.f(this.f82006a) && !c()) {\n return true;\n }\n if ((at.g(this.f82006a) && !b()) || at.h(this.f82006a)) {\n return true;\n }\n }\n return false;\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "void mo4828a(C0152fo foVar, boolean z);", "boolean mo4830a();", "boolean mo28892c(int i);", "public void mo97903a(boolean z) {\n }", "void boolean1(boolean a);", "public interface C0736a {\n void mo559a(C0724g c0724g, boolean z);\n\n boolean mo560a(C0724g c0724g);\n }", "boolean mo44967d();", "public void am(boolean z) {\n }", "public void ak(boolean z) {\n }", "void mo26249mh(boolean z);", "public interface ay {\n void m397a(C0197a c0197a, boolean z);\n\n void m398a(C0198b c0198b, boolean z);\n\n void m399a(C0199c c0199c, boolean z);\n\n void m400a(C0200d c0200d, boolean z);\n\n boolean m401a();\n\n boolean m402b();\n\n byte[] m403c();\n\n String m404d();\n}", "public abstract boolean mo66251a(Result<T> result);", "@Nullable\n /* renamed from: a */\n public abstract C4891ao mo18474a(Object obj, boolean z);", "boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);", "public boolean c(amj paramamj)\r\n/* 559: */ {\r\n/* 560:598 */ for (int i = 0; i < this.b.length; i++) {\r\n/* 561:599 */ if ((this.b[i] != null) && (this.b[i].a(paramamj))) {\r\n/* 562:600 */ return true;\r\n/* 563: */ }\r\n/* 564: */ }\r\n/* 565:603 */ for (i = 0; i < this.a.length; i++) {\r\n/* 566:604 */ if ((this.a[i] != null) && (this.a[i].a(paramamj))) {\r\n/* 567:605 */ return true;\r\n/* 568: */ }\r\n/* 569: */ }\r\n/* 570:608 */ return false;\r\n/* 571: */ }", "public boolean b() {\n/* 365 */ switch (this.h) {\n/* */ case 0:\n/* */ case 1:\n/* 368 */ return true;\n/* */ case 2:\n/* 370 */ return false;\n/* */ } \n/* 372 */ throw new IllegalArgumentException(\"Non JPEG 2000 part I component transformation\");\n/* */ }", "public boolean a(aog ☃) {\r\n/* 179 */ if (!☃.dK()) {\r\n/* 180 */ return false;\r\n/* */ }\r\n/* 182 */ if ((☃.bJ()).B) {\r\n/* 183 */ ☃.a(this);\r\n/* */ }", "abstract public boolean alphaConversion();", "public abstract boolean mo36211n();", "protected abstract boolean mo1601a(C2175k c2175k, long j, C2232a c2232a);", "void mo28195a(C5670a aVar, boolean z);", "boolean mo305a(int i);", "public abstract boolean mo9739d(int i);", "public boolean b(atr paramatr)\r\n/* 468: */ {\r\n/* 469:481 */ if (paramatr.r().l()) {\r\n/* 470:482 */ return true;\r\n/* 471: */ }\r\n/* 472:485 */ amj localamj = a(this.c);\r\n/* 473:486 */ if (localamj != null) {\r\n/* 474:487 */ return localamj.b(paramatr);\r\n/* 475: */ }\r\n/* 476:489 */ return false;\r\n/* 477: */ }", "public abstract boolean mo9735b();", "public abstract void mo32007dM(boolean z);", "public boolean a(World paramaqu, BlockPosition paramdt, EnumDirection paramej)\r\n/* 42: */ {\r\n/* 43: 62 */ return false;\r\n/* 44: */ }", "boolean mo44966c();", "public boolean a(alq paramalq)\r\n/* 247: */ {\r\n/* 248:266 */ int i = c(paramalq);\r\n/* 249:267 */ if (i < 0) {\r\n/* 250:268 */ return false;\r\n/* 251: */ }\r\n/* 252:270 */ if (--this.a[i].b <= 0) {\r\n/* 253:271 */ this.a[i] = null;\r\n/* 254: */ }\r\n/* 255:274 */ return true;\r\n/* 256: */ }", "private static boolean m145767a(int i) {\n return i == 2 || i == 1;\n }", "public boolean a(ahd paramahd)\r\n/* 548: */ {\r\n/* 549:588 */ if (this.d.I) {\r\n/* 550:589 */ return false;\r\n/* 551: */ }\r\n/* 552:591 */ if (paramahd.h(this.d) > 64.0D) {\r\n/* 553:592 */ return false;\r\n/* 554: */ }\r\n/* 555:594 */ return true;\r\n/* 556: */ }", "public final void mo5689a(boolean z) {\n }", "final boolean m20378a(long j) {\n if (j < 200 || j < 0) {\n this.f23490f = 200;\n String str = cz.f23362a;\n } else {\n this.f23490f = j;\n }\n boolean a = super.a(j);\n m20376b();\n return a;\n }", "public void ai(boolean z) {\n }", "protected void a(int paramInt1, int paramInt2, boolean paramBoolean, yz paramyz) {}", "public boolean b(int paramInt, ItemStack paramamj)\r\n/* 86: */ {\r\n/* 87:107 */ return true;\r\n/* 88: */ }", "boolean mo1835a();", "private final boolean m42355b(int i) {\n return i == 0;\n }", "public abstract boolean e(int i2);", "boolean mo54451p(int i);", "public boolean a(ItemStack paramamj, ajk paramajk)\r\n/* 69: */ {\r\n/* 70:131 */ return paramajk.g > 90;\r\n/* 71: */ }", "boolean mo56158b(int i, int i2);", "boolean mo54442g();", "private boolean mo102a(int i) {\n switch (i) {\n case 0:\n return true;\n case 1:\n return this.f340a != null;\n case 2:\n return this.f341b != null;\n case 3:\n return (this.f341b == null || this.f340a == null) ? false : true;\n default:\n return false;\n }\n }", "public interface C8111a {\n /* renamed from: a */\n long mo25071a(long j);\n\n /* renamed from: a */\n C8438u mo25072a(C8438u uVar);\n\n /* renamed from: a */\n AudioProcessor[] mo25073a();\n\n /* renamed from: b */\n long mo25074b();\n }", "boolean mo307b(int i);", "public Boolean asBoolean();", "public void ad(boolean z, int i) {\n }", "boolean mo54453r(int i);", "boolean mo4831a(C0153fp fpVar);" ]
[ "0.69105285", "0.6891783", "0.68860084", "0.6843701", "0.68334794", "0.6818299", "0.6763213", "0.676158", "0.6746595", "0.6720068", "0.6718439", "0.67009383", "0.66983294", "0.66639644", "0.66607267", "0.66521364", "0.6642597", "0.6601423", "0.65878534", "0.6584781", "0.64540553", "0.64142144", "0.6401501", "0.63923174", "0.63867164", "0.6383398", "0.6381991", "0.6356726", "0.63522774", "0.632203", "0.63125086", "0.6305993", "0.6282629", "0.6273208", "0.62688506", "0.6246306", "0.6226097", "0.6195126", "0.6194253", "0.61908466", "0.618404", "0.61554974", "0.6149571", "0.6137795", "0.61284095", "0.6124342", "0.6120299", "0.61008435", "0.6098163", "0.6097824", "0.6092634", "0.60850936", "0.6080379", "0.607034", "0.6068234", "0.60526687", "0.605094", "0.60427666", "0.6037258", "0.60287553", "0.6019765", "0.6014245", "0.6005216", "0.6000992", "0.5993988", "0.59851325", "0.59830916", "0.59796447", "0.59792787", "0.59740686", "0.59642494", "0.59551585", "0.59550625", "0.59477645", "0.59441155", "0.5939641", "0.59375006", "0.59344554", "0.5933511", "0.5930877", "0.59188575", "0.59175706", "0.59155756", "0.59154606", "0.5901246", "0.5881841", "0.58807355", "0.5863642", "0.58626395", "0.584851", "0.5848111", "0.5845819", "0.58449376", "0.5840429", "0.5825605", "0.5824914", "0.582488", "0.5817361", "0.58158", "0.58132404", "0.5811741" ]
0.0
-1
$FF: renamed from: a (int, int, int, aji, int) void
public void method_2110(int var1, int var2, int var3, aji var4, int var5) { this.method_2111(var1, var2, var3, var4, var5, 0); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public abstract int a(long j2, int i2);", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "public void mo44231a(int i) {\n }", "void mo122221a(int i);", "void mo7301a(int i, int i2);", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "public abstract void mo102900a(int i, int i2);", "interface C3069a {\n @C0193h0\n /* renamed from: a */\n Bitmap mo12204a(int i, int i2, Config config);\n\n /* renamed from: a */\n void mo12205a(Bitmap bitmap);\n\n /* renamed from: a */\n void mo12206a(byte[] bArr);\n\n /* renamed from: a */\n void mo12207a(int[] iArr);\n\n /* renamed from: a */\n int[] mo12208a(int i);\n\n /* renamed from: b */\n byte[] mo12209b(int i);\n }", "public abstract void mo4362a(int i, int i2);", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "public abstract void mo4377b(int i, int i2);", "void mo54407a(int i, int i2);", "void mo63037a(int i, int i2);", "void mo66998a(int i);", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "public abstract void mo9800a(int i, int i2);", "public interface C8111a {\n /* renamed from: a */\n long mo25071a(long j);\n\n /* renamed from: a */\n C8438u mo25072a(C8438u uVar);\n\n /* renamed from: a */\n AudioProcessor[] mo25073a();\n\n /* renamed from: b */\n long mo25074b();\n }", "void mo66999a(int i, int i2);", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "void mo22044oA(int i);", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public abstract long a(long j2, long j3);", "void mo7438a(int i, int i2);", "void mo54406a(int i);", "void mo4102a(int i, int i2);", "void mo17008a(int i, int i2);", "public abstract void mo9801a(int i, long j);", "public abstract void mo9733a(int i);", "void mo26876a(int i);", "public abstract void mo4386e(int i, int i2);", "void mo7304b(int i, int i2);", "void mo54408a(int i, int i2, int i3, int i4);", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "void mo27576a(int i);", "void mo88773a(int i);", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "public void mo5332a(int i) {\n }", "void mo63039b(int i, int i2);", "interface C1069a {\n /* renamed from: a */\n C1000w mo7300a(int i);\n\n /* renamed from: a */\n void mo7301a(int i, int i2);\n\n /* renamed from: a */\n void mo7302a(int i, int i2, Object obj);\n\n /* renamed from: a */\n void mo7303a(C1070b bVar);\n\n /* renamed from: b */\n void mo7304b(int i, int i2);\n\n /* renamed from: b */\n void mo7305b(C1070b bVar);\n\n /* renamed from: c */\n void mo7306c(int i, int i2);\n\n /* renamed from: d */\n void mo7308d(int i, int i2);\n }", "void mo17009a(int i, int i2, int i3);", "void mo17017a(int i, int i2);", "void mo1747a(int i);", "public abstract int b(int i2, int i3);", "void m15858a(int i);", "void mo62991a(int i);", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "void m15860a(int i, int i2, int i3);", "void mo38565a(int i);", "void mo1639a(ayl ayl);", "public abstract void mo4361a(int i);", "void mo56156a(int i, int i2);", "void m15859a(int i, int i2);", "interface C9349bs {\n /* renamed from: a */\n int mo28885a(int i);\n\n /* renamed from: a */\n void mo28886a(int i, double d) throws zzlm;\n\n /* renamed from: a */\n void mo28887a(int i, int i2, zzno zzno) throws IOException, InterruptedException;\n\n /* renamed from: a */\n void mo28888a(int i, long j, long j2) throws zzlm;\n\n /* renamed from: a */\n void mo28889a(int i, String str) throws zzlm;\n\n /* renamed from: b */\n void mo28890b(int i) throws zzlm;\n\n /* renamed from: b */\n void mo28891b(int i, long j) throws zzlm;\n\n /* renamed from: c */\n boolean mo28892c(int i);\n}", "public interface C2950c {\n /* renamed from: a */\n int mo9690a(int i, int i2);\n\n /* renamed from: a */\n int mo9691a(String str, String str2, float f);\n\n /* renamed from: a */\n int mo9692a(String[] strArr, int i);\n\n /* renamed from: a */\n void mo9693a();\n\n /* renamed from: a */\n void mo9694a(float f, float f2);\n\n /* renamed from: a */\n void mo9695a(float f, float f2, float f3, float f4, float f5);\n\n /* renamed from: a */\n void mo9696a(float f, float f2, int i);\n\n /* renamed from: a */\n void mo9697a(String str);\n\n /* renamed from: a */\n void mo9698a(String str, float f);\n\n /* renamed from: a */\n void mo9699a(String str, String str2, boolean z);\n\n /* renamed from: a */\n void mo9700a(String str, boolean z);\n\n /* renamed from: a */\n void mo9701a(boolean z);\n\n /* renamed from: b */\n int mo9702b(String str, String str2, float f);\n\n /* renamed from: b */\n void mo9703b(float f, float f2);\n\n /* renamed from: b */\n void mo9704b(float f, float f2, int i);\n\n /* renamed from: c */\n void mo9705c(float f, float f2);\n}", "public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}", "public abstract void mo4381c(int i, int i2);", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public interface C0141g {\n /* renamed from: a */\n void mo84a();\n\n /* renamed from: a */\n void mo85a(int i);\n\n /* renamed from: a */\n void mo86a(C0163d c0163d);\n\n /* renamed from: a */\n void mo87a(String str);\n\n /* renamed from: a */\n void mo88a(byte[] bArr, int i, int i2);\n\n /* renamed from: b */\n C0139e mo89b();\n}", "public abstract void mo9810b(int i, int i2);", "public void a(int paramInt, amj paramamj)\r\n/* 364: */ {\r\n/* 365:385 */ amj[] arrayOfamj = this.a;\r\n/* 366:386 */ if (paramInt >= arrayOfamj.length)\r\n/* 367: */ {\r\n/* 368:387 */ paramInt -= arrayOfamj.length;\r\n/* 369:388 */ arrayOfamj = this.b;\r\n/* 370: */ }\r\n/* 371:391 */ arrayOfamj[paramInt] = paramamj;\r\n/* 372: */ }", "public void mo3350a(int i) {\n }", "void mo3767a(int i);", "void mo17016a(int i);", "void mo6888a(int i);", "public void a(float paramFloat, int paramInt)\r\n/* 15: */ {\r\n/* 16:132 */ bsu.z().N().a(bvo.a);\r\n/* 17:133 */ bub.a(0, 0, 128.0F, 0.0F, 16, 16, 256.0F, 256.0F);\r\n/* 18: */ }", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "public abstract void a(b paramb, int paramInt1, int paramInt2);", "void mo1933b(int i);", "public void b(amj paramamj)\r\n/* 538: */ {\r\n/* 539:579 */ this.f = paramamj;\r\n/* 540: */ }", "void mo17007a(int i);", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "public abstract void mo4376b(int i);", "void mo41083a();", "public abstract int mo4307b(int i);", "public abstract void mo4364a(int i, zzud zzud);", "public abstract void mo9809b(int i);", "void mo28194a();", "public void a(int paramInt1, int paramInt2, float paramFloat)\r\n/* 23: */ {\r\n/* 24:22 */ a(0, 0, this.l, this.m, -12574688, -11530224);\r\n/* 25: */ \r\n/* 26:24 */ a(this.q, this.a, this.l / 2, 90, 16777215);\r\n/* 27:25 */ a(this.q, this.f, this.l / 2, 110, 16777215);\r\n/* 28: */ \r\n/* 29:27 */ super.a(paramInt1, paramInt2, paramFloat);\r\n/* 30: */ }", "public void a(ik paramik)\r\n/* 59: */ {\r\n/* 60:66 */ paramik.a(this);\r\n/* 61: */ }", "void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);", "public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }", "void mo1485a(int i);", "public void a(i iVar) {\n }", "public interface C32231g {\n /* renamed from: a */\n void mo8280a(int i, int i2, C1207m c1207m);\n}", "void mo7444g(int i, int i2);", "void mo7443f(int i, int i2);", "public abstract void mo4369a(long j);", "public interface a {\n void a(int i, List<String> list, boolean z, long j, String str, String str2, String str3);\n }", "void mo28306a();", "public abstract C14407a mo11604a(int i);", "public interface C4773c {\n /* renamed from: a */\n void m15858a(int i);\n\n /* renamed from: a */\n void m15859a(int i, int i2);\n\n /* renamed from: a */\n void m15860a(int i, int i2, int i3);\n\n /* renamed from: b */\n void m15861b(int i, int i2);\n}", "void mo22249a();", "void mo7445h(int i, int i2);", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "void mo34684de(int i, int i2);" ]
[ "0.7276333", "0.7103966", "0.69795847", "0.6921621", "0.6908564", "0.68919224", "0.68878084", "0.6887433", "0.6884476", "0.68742794", "0.6850516", "0.68490016", "0.6846675", "0.6835564", "0.6816136", "0.680056", "0.67879", "0.6778899", "0.67737514", "0.6764913", "0.6756868", "0.6755881", "0.6754112", "0.6751689", "0.6739474", "0.6732386", "0.6720817", "0.67171264", "0.67072976", "0.670054", "0.6697215", "0.66956294", "0.6692384", "0.66738445", "0.6673413", "0.6672444", "0.6663982", "0.666368", "0.66568357", "0.6656035", "0.66507274", "0.6648378", "0.66416013", "0.66333133", "0.66193837", "0.6618871", "0.66139114", "0.6613316", "0.6612793", "0.66042596", "0.6603476", "0.6600815", "0.6599481", "0.6597006", "0.6596763", "0.65904874", "0.658525", "0.657049", "0.6562207", "0.65604883", "0.6558489", "0.6554442", "0.65509313", "0.6549959", "0.65439177", "0.65419024", "0.6541467", "0.65401435", "0.6531208", "0.6529422", "0.65259117", "0.65253323", "0.6509754", "0.6503847", "0.650171", "0.64997315", "0.6498414", "0.6493661", "0.6491192", "0.64844054", "0.6483495", "0.64782083", "0.6472442", "0.6471655", "0.64712745", "0.6467345", "0.6467228", "0.64671946", "0.6464009", "0.646349", "0.6453993", "0.6452253", "0.64512867", "0.6440964", "0.64382005", "0.64297837", "0.642285", "0.6411814", "0.6408263", "0.6406728", "0.6403989" ]
0.0
-1
$FF: renamed from: a (int, int, int, aji, int, int) void
public void method_2111(int param1, int param2, int param3, aji param4, int param5, int param6) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "interface C3069a {\n @C0193h0\n /* renamed from: a */\n Bitmap mo12204a(int i, int i2, Config config);\n\n /* renamed from: a */\n void mo12205a(Bitmap bitmap);\n\n /* renamed from: a */\n void mo12206a(byte[] bArr);\n\n /* renamed from: a */\n void mo12207a(int[] iArr);\n\n /* renamed from: a */\n int[] mo12208a(int i);\n\n /* renamed from: b */\n byte[] mo12209b(int i);\n }", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "public void mo44231a(int i) {\n }", "void mo122221a(int i);", "public abstract int a(long j2, int i2);", "void mo7301a(int i, int i2);", "public abstract void mo102900a(int i, int i2);", "public abstract void mo4362a(int i, int i2);", "public interface C8111a {\n /* renamed from: a */\n long mo25071a(long j);\n\n /* renamed from: a */\n C8438u mo25072a(C8438u uVar);\n\n /* renamed from: a */\n AudioProcessor[] mo25073a();\n\n /* renamed from: b */\n long mo25074b();\n }", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "public abstract void mo4377b(int i, int i2);", "void mo54407a(int i, int i2);", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "void mo66998a(int i);", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "void mo63037a(int i, int i2);", "public abstract void mo9800a(int i, int i2);", "void mo66999a(int i, int i2);", "void mo22044oA(int i);", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "void mo54406a(int i);", "public abstract void mo9733a(int i);", "void mo54408a(int i, int i2, int i3, int i4);", "void mo7438a(int i, int i2);", "interface C1069a {\n /* renamed from: a */\n C1000w mo7300a(int i);\n\n /* renamed from: a */\n void mo7301a(int i, int i2);\n\n /* renamed from: a */\n void mo7302a(int i, int i2, Object obj);\n\n /* renamed from: a */\n void mo7303a(C1070b bVar);\n\n /* renamed from: b */\n void mo7304b(int i, int i2);\n\n /* renamed from: b */\n void mo7305b(C1070b bVar);\n\n /* renamed from: c */\n void mo7306c(int i, int i2);\n\n /* renamed from: d */\n void mo7308d(int i, int i2);\n }", "void mo26876a(int i);", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void mo4102a(int i, int i2);", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "void mo17008a(int i, int i2);", "void mo27576a(int i);", "public void mo5332a(int i) {\n }", "public abstract long a(long j2, long j3);", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "public abstract void mo4386e(int i, int i2);", "void mo7304b(int i, int i2);", "void mo17009a(int i, int i2, int i3);", "public abstract void mo9801a(int i, long j);", "public interface C2950c {\n /* renamed from: a */\n int mo9690a(int i, int i2);\n\n /* renamed from: a */\n int mo9691a(String str, String str2, float f);\n\n /* renamed from: a */\n int mo9692a(String[] strArr, int i);\n\n /* renamed from: a */\n void mo9693a();\n\n /* renamed from: a */\n void mo9694a(float f, float f2);\n\n /* renamed from: a */\n void mo9695a(float f, float f2, float f3, float f4, float f5);\n\n /* renamed from: a */\n void mo9696a(float f, float f2, int i);\n\n /* renamed from: a */\n void mo9697a(String str);\n\n /* renamed from: a */\n void mo9698a(String str, float f);\n\n /* renamed from: a */\n void mo9699a(String str, String str2, boolean z);\n\n /* renamed from: a */\n void mo9700a(String str, boolean z);\n\n /* renamed from: a */\n void mo9701a(boolean z);\n\n /* renamed from: b */\n int mo9702b(String str, String str2, float f);\n\n /* renamed from: b */\n void mo9703b(float f, float f2);\n\n /* renamed from: b */\n void mo9704b(float f, float f2, int i);\n\n /* renamed from: c */\n void mo9705c(float f, float f2);\n}", "void mo88773a(int i);", "interface C9349bs {\n /* renamed from: a */\n int mo28885a(int i);\n\n /* renamed from: a */\n void mo28886a(int i, double d) throws zzlm;\n\n /* renamed from: a */\n void mo28887a(int i, int i2, zzno zzno) throws IOException, InterruptedException;\n\n /* renamed from: a */\n void mo28888a(int i, long j, long j2) throws zzlm;\n\n /* renamed from: a */\n void mo28889a(int i, String str) throws zzlm;\n\n /* renamed from: b */\n void mo28890b(int i) throws zzlm;\n\n /* renamed from: b */\n void mo28891b(int i, long j) throws zzlm;\n\n /* renamed from: c */\n boolean mo28892c(int i);\n}", "void mo1747a(int i);", "public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}", "void mo62991a(int i);", "void mo1639a(ayl ayl);", "void m15860a(int i, int i2, int i3);", "void mo63039b(int i, int i2);", "void m15858a(int i);", "void mo17017a(int i, int i2);", "public interface C0141g {\n /* renamed from: a */\n void mo84a();\n\n /* renamed from: a */\n void mo85a(int i);\n\n /* renamed from: a */\n void mo86a(C0163d c0163d);\n\n /* renamed from: a */\n void mo87a(String str);\n\n /* renamed from: a */\n void mo88a(byte[] bArr, int i, int i2);\n\n /* renamed from: b */\n C0139e mo89b();\n}", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "void mo38565a(int i);", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public abstract void mo4361a(int i);", "void mo56156a(int i, int i2);", "void m15859a(int i, int i2);", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "void mo17016a(int i);", "void mo3767a(int i);", "public abstract void mo4381c(int i, int i2);", "public void mo3350a(int i) {\n }", "public abstract int b(int i2, int i3);", "void mo6888a(int i);", "public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }", "void mo17007a(int i);", "public void a(int paramInt, amj paramamj)\r\n/* 364: */ {\r\n/* 365:385 */ amj[] arrayOfamj = this.a;\r\n/* 366:386 */ if (paramInt >= arrayOfamj.length)\r\n/* 367: */ {\r\n/* 368:387 */ paramInt -= arrayOfamj.length;\r\n/* 369:388 */ arrayOfamj = this.b;\r\n/* 370: */ }\r\n/* 371:391 */ arrayOfamj[paramInt] = paramamj;\r\n/* 372: */ }", "void mo41083a();", "void mo28194a();", "public abstract void mo9810b(int i, int i2);", "void mo1933b(int i);", "public interface C32231g {\n /* renamed from: a */\n void mo8280a(int i, int i2, C1207m c1207m);\n}", "public interface C4773c {\n /* renamed from: a */\n void m15858a(int i);\n\n /* renamed from: a */\n void m15859a(int i, int i2);\n\n /* renamed from: a */\n void m15860a(int i, int i2, int i3);\n\n /* renamed from: b */\n void m15861b(int i, int i2);\n}", "public abstract void mo4364a(int i, zzud zzud);", "public abstract void mo4376b(int i);", "void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);", "public void a(float paramFloat, int paramInt)\r\n/* 15: */ {\r\n/* 16:132 */ bsu.z().N().a(bvo.a);\r\n/* 17:133 */ bub.a(0, 0, 128.0F, 0.0F, 16, 16, 256.0F, 256.0F);\r\n/* 18: */ }", "public abstract void mo9809b(int i);", "void mo28306a();", "public abstract int mo4307b(int i);", "void mo1485a(int i);", "public void b(amj paramamj)\r\n/* 538: */ {\r\n/* 539:579 */ this.f = paramamj;\r\n/* 540: */ }", "public interface a {\n void a(int i, List<String> list, boolean z, long j, String str, String str2, String str3);\n }", "public abstract void mo53562a(C18796a c18796a);", "void mo22249a();", "void mo38026a();", "public void a(i iVar) {\n }", "public void a(ik paramik)\r\n/* 59: */ {\r\n/* 60:66 */ paramik.a(this);\r\n/* 61: */ }", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "public abstract void a(b paramb, int paramInt1, int paramInt2);", "public interface C24221b extends C28343z<C28318an> {\n /* renamed from: a */\n void mo62991a(int i);\n\n String aw_();\n\n /* renamed from: e */\n Aweme mo62993e();\n}", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "public abstract C14407a mo11604a(int i);", "public void a(int paramInt1, int paramInt2, float paramFloat)\r\n/* 23: */ {\r\n/* 24:22 */ a(0, 0, this.l, this.m, -12574688, -11530224);\r\n/* 25: */ \r\n/* 26:24 */ a(this.q, this.a, this.l / 2, 90, 16777215);\r\n/* 27:25 */ a(this.q, this.f, this.l / 2, 110, 16777215);\r\n/* 28: */ \r\n/* 29:27 */ super.a(paramInt1, paramInt2, paramFloat);\r\n/* 30: */ }", "public interface C0937a {\n /* renamed from: a */\n void mo3807a(C0985po[] poVarArr);\n }" ]
[ "0.7299391", "0.7136177", "0.6951789", "0.6916067", "0.69077414", "0.69005", "0.6896973", "0.6896041", "0.68820375", "0.68550533", "0.68526226", "0.6831948", "0.6823842", "0.68104184", "0.6802375", "0.6790018", "0.67871004", "0.67844826", "0.67744833", "0.6767527", "0.67588186", "0.6738685", "0.6723875", "0.6720029", "0.6705638", "0.67034173", "0.6692512", "0.6690557", "0.66900563", "0.6685153", "0.6679882", "0.667756", "0.66775185", "0.66765976", "0.66686034", "0.6650946", "0.66418225", "0.66408914", "0.6640071", "0.66359496", "0.66343194", "0.6634256", "0.6633808", "0.66289717", "0.66277957", "0.6616289", "0.661382", "0.66084236", "0.6601978", "0.65981686", "0.6597519", "0.659691", "0.65940917", "0.6592531", "0.6588832", "0.6585003", "0.65848786", "0.6583273", "0.6582454", "0.657633", "0.6566226", "0.65600306", "0.6553055", "0.6551567", "0.65461457", "0.65317935", "0.6530808", "0.6524618", "0.651724", "0.65152836", "0.65018314", "0.6499968", "0.6495438", "0.649273", "0.6490114", "0.64898", "0.6481301", "0.6479482", "0.64773935", "0.647147", "0.64616555", "0.6456799", "0.6455182", "0.64506316", "0.6450571", "0.6443404", "0.6439269", "0.643896", "0.6433748", "0.6427929", "0.64245605", "0.6421681", "0.64141333", "0.6414022", "0.6409848", "0.6409296", "0.6408412", "0.64056724", "0.64031196", "0.6402819", "0.6396696" ]
0.0
-1
$FF: renamed from: b (int, int, int, aji, int, int) void
public void method_2112(int param1, int param2, int param3, aji param4, int param5, int param6) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo2508a(bxb bxb);", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public abstract int b(int i2, int i3);", "public abstract void zzc(B b, int i, int i2);", "private bxl(bxj parambxj, int paramInt1, int paramInt2, int paramInt3, int paramInt4, int paramInt5, ahh paramahh)\r\n/* 7: */ {\r\n/* 8:75 */ super(paramInt1, paramInt2, paramInt3, paramInt4, paramInt5, bxj.a(parambxj, paramahh));\r\n/* 9:76 */ this.p = paramahh;\r\n/* 10: */ }", "public abstract void zzb(B b, int i, long j);", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "public void b(amj paramamj)\r\n/* 538: */ {\r\n/* 539:579 */ this.f = paramamj;\r\n/* 540: */ }", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "public abstract void a(b paramb, int paramInt1, int paramInt2);", "public abstract void mo4377b(int i, int i2);", "public abstract void mo9810b(int i, int i2);", "public abstract void zza(B b, int i, long j);", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "public abstract void mo9809b(int i);", "private int b(String paramString, float paramFloat1, float paramFloat2, int paramInt, boolean paramBoolean)\r\n/* 426: */ {\r\n/* 427:421 */ if (paramString == null) {\r\n/* 428:422 */ return 0;\r\n/* 429: */ }\r\n/* 430:424 */ if (this.l) {\r\n/* 431:425 */ paramString = c(paramString);\r\n/* 432: */ }\r\n/* 433:428 */ if ((paramInt & 0xFC000000) == 0) {\r\n/* 434:429 */ paramInt |= 0xFF000000;\r\n/* 435: */ }\r\n/* 436:432 */ if (paramBoolean) {\r\n/* 437:433 */ paramInt = (paramInt & 0xFCFCFC) >> 2 | paramInt & 0xFF000000;\r\n/* 438: */ }\r\n/* 439:436 */ this.m = ((paramInt >> 16 & 0xFF) / 255.0F);\r\n/* 440:437 */ this.n = ((paramInt >> 8 & 0xFF) / 255.0F);\r\n/* 441:438 */ this.o = ((paramInt & 0xFF) / 255.0F);\r\n/* 442:439 */ this.p = ((paramInt >> 24 & 0xFF) / 255.0F);\r\n/* 443: */ \r\n/* 444:441 */ cjm.c(this.m, this.n, this.o, this.p);\r\n/* 445: */ \r\n/* 446:443 */ this.i = paramFloat1;\r\n/* 447:444 */ this.j = paramFloat2;\r\n/* 448:445 */ a(paramString, paramBoolean);\r\n/* 449: */ \r\n/* 450:447 */ return (int)this.i;\r\n/* 451: */ }", "public void a(float paramFloat, int paramInt)\r\n/* 15: */ {\r\n/* 16:132 */ bsu.z().N().a(bvo.a);\r\n/* 17:133 */ bub.a(0, 0, 128.0F, 0.0F, 16, 16, 256.0F, 256.0F);\r\n/* 18: */ }", "public abstract void zza(B b, int i, zzeh zzeh);", "public abstract void mo70702a(C30989b c30989b);", "void mo63039b(int i, int i2);", "public abstract int mo4307b(int i);", "void mo7304b(int i, int i2);", "public boolean b(int paramInt, amj paramamj)\r\n/* 578: */ {\r\n/* 579:621 */ return true;\r\n/* 580: */ }", "public abstract void mo9811b(int i, long j);", "public abstract void mo4376b(int i);", "public abstract int a(long j2, int i2);", "public abstract C14407a mo11608b(int i);", "void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);", "public abstract int a(int i, byte[] bArr, int i2, int i3);", "public abstract void mo9798a(byte b);", "void mo1933b(int i);", "public abstract void mo4380b(byte[] bArr, int i, int i2);", "public void b(ahd paramahd) {}", "@Override\n public void func_104112_b() {\n \n }", "public abstract void mo9734b(int i);", "public abstract void mo4360a(byte b);", "public abstract void mo9244b(C0620bi biVar);", "public void b(fv paramfv)\r\n/* 408: */ {\r\n/* 409:423 */ this.a = new amj[36];\r\n/* 410:424 */ this.b = new amj[4];\r\n/* 411:425 */ for (int i = 0; i < paramfv.c(); i++)\r\n/* 412: */ {\r\n/* 413:426 */ fn localfn = paramfv.b(i);\r\n/* 414:427 */ int j = localfn.d(\"Slot\") & 0xFF;\r\n/* 415:428 */ amj localamj = amj.a(localfn);\r\n/* 416:429 */ if (localamj != null)\r\n/* 417: */ {\r\n/* 418:430 */ if ((j >= 0) && (j < this.a.length)) {\r\n/* 419:431 */ this.a[j] = localamj;\r\n/* 420: */ }\r\n/* 421:433 */ if ((j >= 100) && (j < this.b.length + 100)) {\r\n/* 422:434 */ this.b[(j - 100)] = localamj;\r\n/* 423: */ }\r\n/* 424: */ }\r\n/* 425: */ }\r\n/* 426: */ }", "public void b() {\r\n }", "public abstract void mo102900a(int i, int i2);", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "public void mo5356b(int i, int i2) {\n }", "public abstract void mo2156b(int i);", "protected b(int mb) {\n/* 87 */ this.b = mb;\n/* */ }", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "public void b(int paramInt1, int paramInt2) {}", "public void b(int paramInt1, int paramInt2) {}", "public void mo115203b(int i, int i2) {\n }", "public u(b paramb)\r\n/* 7: */ {\r\n/* 8: 9 */ this.a = paramb;\r\n/* 9: */ }", "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public abstract void mo9246b(C0707b bVar);", "void mo4103b(int i, int i2);", "@Override\n public void b() {\n }", "void mo1753b(int i);", "public abstract void mo4362a(int i, int i2);", "public abstract void mo9243b(long j);", "public abstract void mo4378b(int i, zzud zzud);", "public abstract void mo4386e(int i, int i2);", "public void b() {\n }", "public void b() {\n }", "public abstract void mo13593a(byte[] bArr, int i, int i2);", "interface C3069a {\n @C0193h0\n /* renamed from: a */\n Bitmap mo12204a(int i, int i2, Config config);\n\n /* renamed from: a */\n void mo12205a(Bitmap bitmap);\n\n /* renamed from: a */\n void mo12206a(byte[] bArr);\n\n /* renamed from: a */\n void mo12207a(int[] iArr);\n\n /* renamed from: a */\n int[] mo12208a(int i);\n\n /* renamed from: b */\n byte[] mo12209b(int i);\n }", "public abstract void mo4379b(int i, zzwt zzwt);", "public abstract void mo4381c(int i, int i2);", "void mo72113b();", "protected void a(bug parambug)\r\n/* 35: */ {\r\n/* 36:36 */ this.j.a((bxf)null);\r\n/* 37: */ }", "public abstract C7035a mo24417b(long j);", "public abstract void mo9800a(int i, int i2);", "public bly(int paramInt, Random paramRandom, bjb parambjb, EnumDirection paramej)\r\n/* 10: */ {\r\n/* 11:831 */ super(paramInt);\r\n/* 12: */ \r\n/* 13:833 */ this.m = paramej;\r\n/* 14:834 */ this.d = a(paramRandom);\r\n/* 15:835 */ this.l = parambjb;\r\n/* 16: */ }", "void mo50321b(C18924b bVar);", "void mo17011b(int i, int i2);", "public void b(ahb paramahb)\r\n/* 583: */ {\r\n/* 584:625 */ for (int i = 0; i < this.a.length; i++) {\r\n/* 585:626 */ this.a[i] = amj.b(paramahb.a[i]);\r\n/* 586: */ }\r\n/* 587:628 */ for (i = 0; i < this.b.length; i++) {\r\n/* 588:629 */ this.b[i] = amj.b(paramahb.b[i]);\r\n/* 589: */ }\r\n/* 590:631 */ this.c = paramahb.c;\r\n/* 591: */ }", "void mo88523b();", "public abstract void mo9801a(int i, long j);", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "void b();", "@Override\n\tpublic void b() {\n\n\t}", "public abstract int b();", "public interface b {\n void a(int i, String str, String str2, String str3);\n\n void a(long j);\n }", "void mo50320a(C18924b bVar);", "void mo54407a(int i, int i2);", "long mo1636a(long j, alb alb);", "public abstract boolean a(e parame, b paramb, int paramInt1, int paramInt2);", "void m15861b(int i, int i2);", "protected abstract void a(bru parambru);", "public abstract long a(long j2, long j3);", "public void mo23981a(C4321b bVar) {\n }", "C4932q5 mo19394a(byte[] bArr) throws zzfn;", "public abstract e a(byte[] bArr, int i, boolean z) throws g;", "void mo17020b(int i);", "public void a(int paramInt, amj paramamj)\r\n/* 364: */ {\r\n/* 365:385 */ amj[] arrayOfamj = this.a;\r\n/* 366:386 */ if (paramInt >= arrayOfamj.length)\r\n/* 367: */ {\r\n/* 368:387 */ paramInt -= arrayOfamj.length;\r\n/* 369:388 */ arrayOfamj = this.b;\r\n/* 370: */ }\r\n/* 371:391 */ arrayOfamj[paramInt] = paramamj;\r\n/* 372: */ }", "public abstract void mo53562a(C18796a c18796a);", "public interface b {\n void a(DownloadInfo downloadInfo, long j, boolean z, int i);\n }", "void mo88a(byte[] bArr, int i, int i2);", "interface C9349bs {\n /* renamed from: a */\n int mo28885a(int i);\n\n /* renamed from: a */\n void mo28886a(int i, double d) throws zzlm;\n\n /* renamed from: a */\n void mo28887a(int i, int i2, zzno zzno) throws IOException, InterruptedException;\n\n /* renamed from: a */\n void mo28888a(int i, long j, long j2) throws zzlm;\n\n /* renamed from: a */\n void mo28889a(int i, String str) throws zzlm;\n\n /* renamed from: b */\n void mo28890b(int i) throws zzlm;\n\n /* renamed from: b */\n void mo28891b(int i, long j) throws zzlm;\n\n /* renamed from: c */\n boolean mo28892c(int i);\n}", "public abstract void zza(B b, int i, T t);", "public interface lh extends lg {\n void a(int i, int i2, int i3, int i4, int i5, int i6, byte[] bArr);\n}", "void mo41086b();", "public amj b(int paramInt)\r\n/* 347: */ {\r\n/* 348:369 */ amj[] arrayOfamj = this.a;\r\n/* 349:370 */ if (paramInt >= this.a.length)\r\n/* 350: */ {\r\n/* 351:371 */ arrayOfamj = this.b;\r\n/* 352:372 */ paramInt -= this.a.length;\r\n/* 353: */ }\r\n/* 354:375 */ if (arrayOfamj[paramInt] != null)\r\n/* 355: */ {\r\n/* 356:376 */ amj localamj = arrayOfamj[paramInt];\r\n/* 357:377 */ arrayOfamj[paramInt] = null;\r\n/* 358:378 */ return localamj;\r\n/* 359: */ }\r\n/* 360:380 */ return null;\r\n/* 361: */ }", "public abstract void mo4369a(long j);" ]
[ "0.7456652", "0.7432349", "0.7361463", "0.73387", "0.7236326", "0.7205104", "0.71879154", "0.71435326", "0.71396005", "0.7136091", "0.71339566", "0.7059009", "0.7009761", "0.7003045", "0.700134", "0.69334495", "0.6921128", "0.69002146", "0.68844306", "0.6864181", "0.6855326", "0.6845264", "0.6844301", "0.6827365", "0.68118006", "0.68049145", "0.67936254", "0.67764986", "0.6766444", "0.67574394", "0.67570126", "0.674937", "0.67394716", "0.6737315", "0.673463", "0.67274654", "0.6724464", "0.6720385", "0.6719773", "0.6701359", "0.6692322", "0.66918945", "0.66858256", "0.6670783", "0.667071", "0.66702545", "0.6670199", "0.6670199", "0.66388553", "0.66194105", "0.66082746", "0.66057825", "0.6605719", "0.6600082", "0.6595689", "0.6594034", "0.65927386", "0.65881735", "0.65833336", "0.6580112", "0.6580112", "0.65766674", "0.6573959", "0.65683216", "0.6562059", "0.6559411", "0.6557632", "0.6551712", "0.65471256", "0.6544778", "0.6541328", "0.65315384", "0.652534", "0.6516679", "0.6516017", "0.6514865", "0.6514068", "0.65086204", "0.650468", "0.6504308", "0.6503316", "0.6497891", "0.64926505", "0.64916855", "0.6488278", "0.6486412", "0.64847916", "0.64839", "0.6480816", "0.6478259", "0.6477935", "0.6477176", "0.64713204", "0.64677656", "0.6462545", "0.64571965", "0.6452625", "0.6441959", "0.6441788", "0.64409196", "0.6439694" ]
0.0
-1
$FF: renamed from: h () void
public void method_2113() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void h() {\n }", "protected void h() {}", "public static void hehe(){\n \n }", "public abstract long h();", "void mo1501h();", "public void mo21783H() {\n }", "@Override\n\tvoid hi() {\n\t}", "public abstract void mh();", "public void mo9233aH() {\n }", "void mo57277b();", "@ReflectiveMethod(name = \"h\", types = {})\n public void h(){\n NMSWrapper.getInstance().exec(nmsObject);\n }", "@ReflectiveMethod(name = \"h\", types = {})\n public void h(){\n NMSWrapper.getInstance().exec(nmsObject);\n }", "public abstract int mo123249h();", "@Hide\n private final zzs zzahx() {\n }", "void mo67923b();", "void mo80455b();", "public void furyo ()\t{\n }", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void mo72113b();", "@Override\n\tpublic void nghe() {\n\n\t}", "void mo119582b();", "void mo41086b();", "public void b(ahd paramahd) {}", "void mo28194a();", "private final void i() {\n }", "public final void h() {\n this.f10064d.c();\n d(false, false, this.f10064d.n().b());\n this.f10064d.p().w(this.f10064d.n().b());\n }", "void mo35722a(C14235h hVar);", "public int h(int i2) {\n return e();\n }", "public boolean h()\r\n/* 189: */ {\r\n/* 190:187 */ return this.g;\r\n/* 191: */ }", "public void hat();", "void mo80452a();", "void mo41083a();", "public void mo6944a() {\n }", "void mo7353b();", "void mo67924c();", "void mo54405a();", "void mo21073d();", "protected void b(dh paramdh) {}", "void mo67920a();", "void mo80457c();", "public void mo97908d() {\n }", "void mo28306a();", "void mo72111a();", "public Void mo7069h() {\n return null;\n }", "void mo57278c();", "public abstract void mo27386d();", "public void t();", "void mo69874a();", "public Husdjurshotell(){}", "void mo88523b();", "public void mo21825b() {\n }", "void mo98969a();", "public abstract void mo70713b();", "void m8368b();", "void id() {}", "void mo22249a();", "private stendhal() {\n\t}", "void mo54435d();", "void mo119581a();", "@Override\n public void b() {\n }", "void mo57275a();", "abstract public void header();", "void mo84655a();", "public com.google.cM h() {\n /*\n r3 = this;\n r0 = new com.google.cM;\n r1 = 0;\n r0.<init>(r3, r1);\n r1 = r3.f;\n r1 = r3.h;\n if (r1 != 0) goto L_0x002a;\n L_0x000c:\n r1 = r3.f;\n r1 = r1 & 1;\n r2 = 1;\n if (r1 != r2) goto L_0x0021;\n L_0x0013:\n r1 = r3.g;\n r1 = java.util.Collections.unmodifiableList(r1);\n r3.g = r1;\n r1 = r3.f;\n r1 = r1 & -2;\n r3.f = r1;\n L_0x0021:\n r1 = r3.g;\n com.google.cM.a(r0, r1);\n r1 = com.google.bA.b;\n if (r1 == 0) goto L_0x0033;\n L_0x002a:\n r1 = r3.h;\n r1 = r1.f();\n com.google.cM.a(r0, r1);\n L_0x0033:\n r3.f();\n return r0;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.google.cX.h():com.google.cM\");\n }", "void mo21074e();", "public abstract void mo102585a(VH vh, int i);", "void mo9693a();", "void mo7372a(C0802fh fhVar) throws RemoteException;", "void mo21076g();", "void mo304a(C0366h c0366h);", "public void g() {\n }", "void mo56163g();", "public void Head() {\n\n\t}", "public /* bridge */ /* synthetic */ void mo22964h(C7059Ec ec) {\n super.mo22964h(ec);\n }", "public void mo21878t() {\n }", "void berechneFlaeche() {\n\t}", "public int h(Block parambec)\r\n/* 29: */ {\r\n/* 30: 44 */ return F();\r\n/* 31: */ }", "public void c(ahd paramahd) {}", "void mo60893b();", "void mo72114c();", "public void mo21779D() {\n }", "public void mo44053a() {\n }", "void mo13368a();", "public void mo2471e() {\n }", "private Parser(FScript h,HashMap l,HashMap g, HashMap f) {\n vars=l;\n gVars=g;\n funcs=f;\n host=h;\n }", "void mo21072c();", "public void b() {\r\n }", "public final void mo91715d() {\n }", "void mo1763h(int i);", "public void m23075a() {\n }", "public abstract void mo6549b();", "void mo88521a();", "public static void hvitetest1w(){\r\n\t}", "C32446a mo21077h() throws Exception;", "private void ss(){\n }", "@Override\n\tpublic void gaga() {\n\t\tthis.zhizhi();\n\t}", "public abstract void mo56925d();", "void mo38026a();", "void mo37810a();", "public abstract void mo35054b();", "public void mo3749d() {\n }" ]
[ "0.84740615", "0.8444737", "0.6805465", "0.6713092", "0.6691926", "0.66518956", "0.6610404", "0.6606491", "0.6573243", "0.6514802", "0.65070736", "0.65070736", "0.6481098", "0.64575875", "0.6442367", "0.6403833", "0.6402855", "0.6402412", "0.6370755", "0.6340479", "0.63323313", "0.632393", "0.6322453", "0.6308392", "0.6303405", "0.62947744", "0.629372", "0.6265744", "0.6258156", "0.62373453", "0.6231072", "0.6228167", "0.62076443", "0.62066615", "0.6199259", "0.61955", "0.61897355", "0.61861205", "0.618283", "0.6180409", "0.61670226", "0.6166221", "0.6160925", "0.6156635", "0.6154924", "0.6150841", "0.615029", "0.61433494", "0.6125087", "0.60993665", "0.60966945", "0.6096222", "0.60956126", "0.6091091", "0.6084271", "0.60690486", "0.6065683", "0.60653186", "0.6065305", "0.6058706", "0.6055221", "0.6054304", "0.60541856", "0.6044754", "0.6044048", "0.60416234", "0.6039752", "0.6033641", "0.6030672", "0.6026036", "0.60204226", "0.6020263", "0.6005715", "0.60033953", "0.6002495", "0.600063", "0.6000419", "0.5998695", "0.59984994", "0.59953773", "0.598376", "0.598167", "0.59815437", "0.5980886", "0.59779876", "0.59747785", "0.5971541", "0.5967455", "0.5964891", "0.5964842", "0.5961857", "0.595639", "0.5956329", "0.59556395", "0.5948665", "0.59466505", "0.5943304", "0.593236", "0.59313244", "0.59281456", "0.5926765" ]
0.0
-1
$FF: renamed from: l () void
public void method_2244() { this.field_1858 = 0; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo1943l();", "void mo54447l(int i);", "public void mo21787L() {\n }", "public void mo3370l() {\n }", "protected float l()\r\n/* 72: */ {\r\n/* 73: 84 */ return 0.0F;\r\n/* 74: */ }", "public abstract int mo9747l();", "@Override\n\tpublic void ligar() {\n\t\t\n\t}", "public void func_70305_f() {}", "public void lavar() {\n\t\t// TODO Auto-generated method stub\n\t\t\n\t}", "void mo28194a();", "public void visitLLOAD(LLOAD o){\n\t\t//visitLoadInstruction(LoadInstruction) is called before.\n\t\t\n\t\t// Nothing else needs to be done here.\n\t}", "void m1864a() {\r\n }", "void mo28306a();", "void mo80452a();", "void mo57277b();", "void mo80455b();", "void mo41083a();", "public static void c1_vl() {\n\t}", "private final void i() {\n }", "void mo72113b();", "public void l()\r\n/* 190: */ {\r\n/* 191:221 */ for (int i = 0; i < this.a.length; i++) {\r\n/* 192:222 */ this.a[i] = null;\r\n/* 193: */ }\r\n/* 194: */ }", "@ReflectiveMethod(name = \"l\", types = {})\n public void l(){\n NMSWrapper.getInstance().exec(nmsObject);\n }", "public void update(L l);", "void mo41086b();", "private void yy() {\n\n\t}", "void mo119582b();", "public abstract void mo32006dL(boolean z);", "void mo54405a();", "public void t();", "public abstract void mo42331g();", "public void g() {\n }", "void mo38026a();", "public static void bi_vl() {\n\t}", "public void m23075a() {\n }", "void mo22249a();", "public void mo6944a() {\n }", "public boolean b()\r\n/* 709: */ {\r\n/* 710:702 */ return this.l;\r\n/* 711: */ }", "public abstract void mo42329d();", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "void mo72111a();", "void mo9693a();", "void mo13368a();", "void mo69874a();", "void mo119581a();", "void mo67923b();", "public void a(cvl paramcvl)\r\n/* 84: */ {\r\n/* 85: 97 */ this.d.add(paramcvl);\r\n/* 86: */ \r\n/* 87: 99 */ paramcvl.a(this);\r\n/* 88: */ }", "void mo80457c();", "void mo84655a();", "public abstract void mo27386d();", "void mo12634a();", "void mo21073d();", "public abstract void mo42330e();", "public void mo38117a() {\n }", "void mo98969a();", "@Override\n public void func_104112_b() {\n \n }", "void mo4873a(C4718l c4718l);", "void mo3311a();", "void mo67920a();", "void mo60892a();", "public void mo42331g() {\n mo42335f();\n }", "void mo54435d();", "void mo105476a();", "public interface lw {\n int b();\n}", "static void feladat9() {\n\t}", "@Override\n\tpublic void lab() {\n\t\t\n\t}", "public void o_() {}", "void mo3193f();", "public void furyo ()\t{\n }", "public void mo21877s() {\n }", "public abstract void mo30696a();", "void mo60893b();", "void mo57275a();", "public void mo21879u() {\n }", "public void h() {\n }", "public abstract void mo27464a();", "static void perform_lhld(String passed){\n\t\tint type = type_of_lhld(passed);\n\t\tif(type==1)\n\t\t\tlhld_from_mem(passed);\n\t}", "void mo21074e();", "void m(int i) {\r\n\t}", "public void mo21878t() {\n }", "protected java.util.List x (java.lang.String r19){\n /*\n r18 = this;\n r0 = r18;\n r2 = r0.K;\n r0 = r19;\n r2 = r2.getAllSortStackTraces(r0);\n r2 = (java.util.List) r2;\n if (r2 == 0) goto L_0x000f;\n L_0x000e:\n return r2;\n L_0x000f:\n r12 = java.util.Collections.emptyList();\n r2 = r18.bp();\n r3 = r18.TaskHandler(r19);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n r4 = r2.setDrawable(r3);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n if (r4 != 0) goto L_0x0026;\n L_0x0021:\n r18.bq();\n r2 = r12;\n goto L_0x000e;\n L_0x0026:\n r13 = r2.getScaledMaximumFlingVelocity(r3);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n r14 = new java.io.ByteArrayOutputStream;\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n r2 = 2048; // 0x800 float:2.87E-42 double:1.0118E-320;\n r14.<creatCallTask>(r2);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n com.duokan.core.io.getTriangleEdge.setDrawable(r13, r14);\t Catch:{ all -> 0x00f2 }\n r2 = r14.toByteArray();\t Catch:{ all -> 0x00f2 }\n r2 = com.duokan.kernel.DkUtils.decodeSimpleDrm(r2);\t Catch:{ all -> 0x00f2 }\n r3 = new java.lang.String;\t Catch:{ all -> 0x00f2 }\n r4 = \"UTF-8\";\n r3.<creatCallTask>(r2, r4);\t Catch:{ all -> 0x00f2 }\n r2 = new org.json.JSONObject;\t Catch:{ all -> 0x00f2 }\n r2.<creatCallTask>(r3);\t Catch:{ all -> 0x00f2 }\n if (r2 != 0) goto L_0x0055;\n L_0x004a:\n com.duokan.core.io.getTriangleEdge.setDrawable(r13);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n com.duokan.core.io.getTriangleEdge.setDrawable(r14);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n r18.bq();\n r2 = r12;\n goto L_0x000e;\n L_0x0055:\n r3 = \"pictures\";\n r15 = com.duokan.reader.common.getPhysicalYPixels.setDrawable(r2, r3);\t Catch:{ all -> 0x00f2 }\n r16 = new java.util.ArrayList;\t Catch:{ all -> 0x00f2 }\n r2 = r15.length();\t Catch:{ all -> 0x00f2 }\n r0 = r16;\n r0.<creatCallTask>(r2);\t Catch:{ all -> 0x00f2 }\n r2 = 0;\n L_0x0067:\n r3 = r15.length();\t Catch:{ all -> 0x00f2 }\n if (r2 >= r3) goto L_0x00d0;\n L_0x006d:\n r3 = r15.getJSONObject(r2);\t Catch:{ all -> 0x00f2 }\n r4 = \"sm_md5\";\n r7 = r3.getString(r4);\t Catch:{ all -> 0x00f2 }\n r4 = \"sm_url\";\n r6 = r3.getString(r4);\t Catch:{ all -> 0x00f2 }\n r4 = \"sm_size\";\n r8 = r3.getLong(r4);\t Catch:{ all -> 0x00f2 }\n r4 = \"width\";\n r10 = r3.getInt(r4);\t Catch:{ all -> 0x00f2 }\n r4 = \"height\";\n r11 = r3.getInt(r4);\t Catch:{ all -> 0x00f2 }\n r3 = new java.lang.StringBuilder;\t Catch:{ all -> 0x00f2 }\n r3.<creatCallTask>();\t Catch:{ all -> 0x00f2 }\n r0 = r19;\n r3 = r3.append(r0);\t Catch:{ all -> 0x00f2 }\n r4 = \".\";\n r3 = r3.append(r4);\t Catch:{ all -> 0x00f2 }\n r3 = r3.append(r2);\t Catch:{ all -> 0x00f2 }\n r4 = r3.toString();\t Catch:{ all -> 0x00f2 }\n r5 = new java.lang.String;\t Catch:{ all -> 0x00f2 }\n r3 = new java.lang.StringBuilder;\t Catch:{ all -> 0x00f2 }\n r3.<creatCallTask>();\t Catch:{ all -> 0x00f2 }\n r17 = \"file:///stuffs/\";\n r0 = r17;\n r3 = r3.append(r0);\t Catch:{ all -> 0x00f2 }\n r3 = r3.append(r7);\t Catch:{ all -> 0x00f2 }\n r3 = r3.toString();\t Catch:{ all -> 0x00f2 }\n r5.<creatCallTask>(r3);\t Catch:{ all -> 0x00f2 }\n r3 = r18;\n r3 = r3.setDrawable(r4, r5, r6, r7, r8, r10, r11);\t Catch:{ all -> 0x00f2 }\n r0 = r16;\n r0.add(r3);\t Catch:{ all -> 0x00f2 }\n r2 = r2 + 1;\n goto L_0x0067;\n L_0x00d0:\n r0 = r18;\n r2 = r0.K;\t Catch:{ all -> 0x00f2 }\n r0 = r19;\n r1 = r16;\n r2.putIfAbsent(r0, r1);\t Catch:{ all -> 0x00f2 }\n r0 = r18;\n r2 = r0.K;\t Catch:{ all -> 0x00f2 }\n r0 = r19;\n r2 = r2.getAllSortStackTraces(r0);\t Catch:{ all -> 0x00f2 }\n r2 = (java.util.List) r2;\t Catch:{ all -> 0x00f2 }\n com.duokan.core.io.getTriangleEdge.setDrawable(r13);\t Catch:{ Throwable -> 0x0106, all -> 0x0101 }\n com.duokan.core.io.getTriangleEdge.setDrawable(r14);\t Catch:{ Throwable -> 0x0106, all -> 0x0101 }\n r18.bq();\n goto L_0x000e;\n L_0x00f2:\n r2 = move-exception;\n com.duokan.core.io.getTriangleEdge.setDrawable(r13);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n com.duokan.core.io.getTriangleEdge.setDrawable(r14);\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n throw r2;\t Catch:{ Throwable -> 0x00fa, all -> 0x0101 }\n L_0x00fa:\n r2 = move-exception;\n r2 = r12;\n L_0x00fc:\n r18.bq();\n goto L_0x000e;\n L_0x0101:\n r2 = move-exception;\n r18.bq();\n throw r2;\n L_0x0106:\n r3 = move-exception;\n goto L_0x00fc;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.duokan.reader.domain.bookshelf.jv.MyContextWrapper(java.lang.String):java.util.List\");\n }", "void mo88521a();", "public lo() {}", "void mo37810a();", "void mo56163g();", "void m8367a();", "void mo21076g();", "@Override\n\tpublic void a() {\n\t\t\n\t}", "private static interface T {@Symbolic Term.List t();}", "public abstract void mo3994a();", "public static void c0_vl() {\n\t}", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void mo57278c();", "public void mo44053a() {\n }", "static void feladat4() {\n\t}", "void mo1970b();", "void mo26876a(int i);", "private void ss(){\n }", "void mo88523b();", "public void a() {\r\n }", "public final void cpp() {\n }", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}" ]
[ "0.6892013", "0.6770438", "0.67282015", "0.6557665", "0.63766724", "0.6365918", "0.6294135", "0.62850064", "0.6259821", "0.62548256", "0.62536395", "0.6212706", "0.6191345", "0.61621934", "0.6140332", "0.61286145", "0.609547", "0.6089261", "0.6055513", "0.6052307", "0.6043603", "0.6026336", "0.60254157", "0.6010843", "0.60078424", "0.59913975", "0.59911525", "0.5979393", "0.5973803", "0.5961962", "0.59604865", "0.5955685", "0.5949387", "0.5946278", "0.5943631", "0.5922426", "0.59172356", "0.5899524", "0.58993506", "0.5898005", "0.5884233", "0.5881083", "0.58778286", "0.5874774", "0.58719474", "0.5870697", "0.5868699", "0.5863314", "0.5856368", "0.58549935", "0.5841724", "0.58259434", "0.58247703", "0.58156884", "0.58077896", "0.57988024", "0.5791443", "0.57910293", "0.5789791", "0.5780597", "0.57763505", "0.5768549", "0.5760354", "0.5748276", "0.5740559", "0.57367486", "0.5722346", "0.5720382", "0.57163954", "0.57130295", "0.5704264", "0.56975836", "0.5696901", "0.5694704", "0.5693384", "0.5692519", "0.56880224", "0.5687979", "0.5686855", "0.56842124", "0.5679842", "0.56797737", "0.5678249", "0.5678037", "0.5674293", "0.56724274", "0.567213", "0.5667868", "0.56672996", "0.56672907", "0.5666666", "0.5666096", "0.56627053", "0.5659015", "0.56517774", "0.5650314", "0.5650212", "0.56469613", "0.5642614", "0.5639581", "0.56366795" ]
0.0
-1
$FF: renamed from: a (boolean) boolean
public boolean method_2153(boolean param1) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public Boolean asBoolean();", "boolean booleanOf();", "void boolean1(boolean a);", "void mo21069a(boolean z);", "void mo64153a(boolean z);", "void mo98208a(boolean z);", "abstract public boolean getAsBoolean();", "void mo99838a(boolean z);", "void mo6661a(boolean z);", "void mo1488a(boolean z);", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "void mo3305a(boolean z);", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "void mo12636a(boolean z);", "void mo1492b(boolean z);", "void mo197b(boolean z);", "public abstract boolean read_boolean();", "void mo9701a(boolean z);", "void mo54420a(boolean z, boolean z2);", "public boolean isBoolean();", "boolean getBoolValue();", "boolean getBoolValue();", "public static Value makeBool(boolean b) {\n if (b)\n return theBoolTrue;\n else\n return theBoolFalse;\n }", "public abstract boolean a();", "@ZenCodeType.Caster\n @ZenCodeType.Method\n default boolean asBool() {\n \n return notSupportedCast(BasicTypeID.BOOL);\n }", "default boolean asBool() {\n\t\tthrow new EvaluatorException(\"Expecting a bool value\");\n\t}", "boolean isEBoolean();", "@ReflectiveMethod(name = \"a\", types = {})\n public boolean a(){\n return (boolean) NMSWrapper.getInstance().exec(nmsObject);\n }", "public boolean getBoolean(String name)\n/* */ {\n/* 845 */ return getBoolean(name, false);\n/* */ }", "abstract void mo956a(boolean z);", "boolean getBoolean();", "boolean getBoolean();", "void mo21071b(boolean z);", "BoolOperation createBoolOperation();", "public boolean getBoolean();", "public void am(boolean z) {\n }", "BooleanLiteralExp createBooleanLiteralExp();", "private CheckBoolean() {\n\t}", "public interface Truth {\n\n /**\n * This method has to be implemented to know whether the\n * object implementing this interface should be treated\n * as a Boolean.TRUE value or Boolean.FALSE\n *\n * This interface has been created in order to\n * make it easier to interact with Groovy collections\n * and participate of the Groovy truth\n *\n * @return the boolean representation of the current type\n */\n public Boolean asBoolean();\n\n}", "boolean hasBool();", "boolean hasBoolValue();", "public boolean sawNonboolean() {\n return nonboolean;\n }", "static public boolean asBoolean(Object a) throws Exception {\r\n\t\tif (a instanceof JSObject)\r\n\t\t\ta = ((JSObject) a).valueOf();\r\n\t\t\r\n\t\t// js types\r\n\t\tif (a instanceof Boolean)\r\n\t\t\treturn (Boolean) a;\r\n\t\tif (a instanceof Double)\r\n\t\t\treturn (Double) a != 0;\r\n\t\tif (a instanceof String)\r\n\t\t\treturn ((String) a).length() > 0;\r\n\t\tif (a == null)\r\n\t\t\treturn false;\r\n\t\tif (a instanceof JSNull)\r\n\t\t\treturn false;\r\n\t\tif (a instanceof JSObject)\r\n\t\t\treturn true;\r\n\t\t\r\n\t\t// java types\r\n\t\tif (a instanceof Number)\r\n\t\t\treturn ((Number) a).doubleValue() > 0;\r\n\t\t\r\n\t\treturn false;\r\n\t}", "boolean mo2803a(boolean z);", "public void mo97903a(boolean z) {\n }", "boolean getValue();", "boolean readBoolean();", "public void method_217(boolean var1) {}", "@JsSupport( {JsVersion.MOZILLA_ONE_DOT_ONE, \r\n\t\tJsVersion.JSCRIPT_TWO_DOT_ZERO})\r\npublic interface Boolean extends Object {\r\n\t\r\n\t@Constructor void Boolean();\r\n\t\r\n\t@Constructor void Boolean(boolean value);\r\n\t\r\n\t@Constructor void Boolean(Number value);\r\n\t\r\n\t@Constructor void Boolean(String value);\r\n\t\r\n\t@Function boolean valueOf();\r\n\t\r\n}", "public void mo97905b(boolean z) {\n }", "public boolean a()\n {\n return true;\n }", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "BooleanExpression createBooleanExpression();", "BooleanExpression createBooleanExpression();", "void visitBooleanValue(BooleanValue value);", "void mo22049es(boolean z);", "public boolean a()\r\n {\r\n return false;\r\n }", "public final void mo5689a(boolean z) {\n }", "public static boolean bVal( Boolean value ) {\n return value != null && value; \n }", "<C> BooleanLiteralExp<C> createBooleanLiteralExp();", "public abstract void mo32006dL(boolean z);", "public Boolean getValue() {\n/* 60 */ return Boolean.valueOf(this.val);\n/* */ }", "public Boolean() {\n\t\tsuper(false);\n\t}", "public void b(boolean paramBoolean)\r\n/* 603: */ {\r\n/* 604:601 */ this.l = paramBoolean;\r\n/* 605: */ }", "public final boolean func_boolean_a(int var1, int var2) {\n if (this.func_boolean_b(var1, var2)) {\n return true;\n } else if (var2 != 53 && var1 != 8) {\n if (var2 == -8) {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)0);\n return true;\n } else {\n return true;\n }\n } else {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)1);\n return true;\n }\n }", "@ReflectiveMethod(name = \"b\", types = {})\n public boolean b(){\n return (boolean) NMSWrapper.getInstance().exec(nmsObject);\n }", "public boolean get(boolean a) {\n\t\treturn a;\r\n\t}", "public Boolean getABoolean()\n {\n return aBoolean;\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "boolean internal();", "public final void mo12411a(boolean z) {\n }", "public static boolean toPrimitiveBoolean(Boolean value) {\n if (value == null) {\n return false;\n }\n return value;\n }", "public static Value makeBool(Bool b) {\n if (b.isMaybeAnyBool())\n return theBoolAny;\n else if (b.isMaybeTrueButNotFalse())\n return theBoolTrue;\n else if (b.isMaybeFalseButNotTrue())\n return theBoolFalse;\n else\n return theNone;\n }", "public void a(boolean paramBoolean)\r\n/* 593: */ {\r\n/* 594:593 */ this.k = paramBoolean;\r\n/* 595: */ }", "public boolean add(boolean a, boolean b){\n\t\tSystem.out.println(\"i am from method where return type is boolean\");\n\t return true;\n\t}", "private boolean isLava() {\n/* 317 */ return this.isLava;\n/* */ }", "boolean mo38970a();", "void mo13377a(boolean z, C15943j c15943j);", "public void ak(boolean z) {\n }", "public void b(boolean paramBoolean)\r\n/* 184: */ {\r\n/* 185:183 */ this.g = paramBoolean;\r\n/* 186: */ }", "public boolean tom();", "BoolConstant createBoolConstant();", "boolean mo1969a();", "boolean mo34114a();", "private boolean getBoolean(String paramString, boolean paramBoolean) {\n }", "public void ae(boolean z) {\n }", "public void setA ( boolean a ) {\n\n\tthis.a = a;\n }", "void mo26249mh(boolean z);", "void mo54415a(int i, boolean z);", "public boolean a(World paramaqu, BlockPosition paramdt, Block parambec, boolean paramBoolean)\r\n/* 67: */ {\r\n/* 68: 83 */ return true;\r\n/* 69: */ }", "public abstract boolean mo66253b();", "public void mo97907c(boolean z) {\n }", "public interface BooleanFunction<T> extends Function<T, Boolean> {\r\n\r\n}", "public boolean getValue();", "public static boolean toBoolean(Boolean value)\r\n {\r\n return toBoolean(value, false);\r\n }", "public Boolean int_to_boolean(int arg){\r\n\t\tif (arg == 1)\r\n\t\t\treturn true;\r\n\t\telse return false;\r\n\t}", "@Nullable\n /* renamed from: a */\n public abstract C4891ao mo18474a(Object obj, boolean z);", "@Test\n public void testCaseOfBool() {\n AtomicBoolean success = new AtomicBoolean(false);\n match(42L).caseOf(true, s -> success.set(true));\n assertTrue(success.get());\n }" ]
[ "0.7910512", "0.7590931", "0.7569646", "0.7515339", "0.7490424", "0.7454948", "0.7451848", "0.74418247", "0.7435433", "0.73873764", "0.73207366", "0.73207366", "0.73207366", "0.73207366", "0.72859126", "0.72447824", "0.71524477", "0.71149015", "0.70981497", "0.70908314", "0.70309836", "0.70037967", "0.6948973", "0.6894811", "0.6894811", "0.68919516", "0.6881043", "0.6865189", "0.68491834", "0.68469423", "0.68388414", "0.6838282", "0.6815486", "0.67862326", "0.67862326", "0.67246884", "0.67157406", "0.6710599", "0.66965556", "0.668036", "0.66379845", "0.6631222", "0.6624382", "0.66137326", "0.66127074", "0.6602181", "0.6587275", "0.6577189", "0.65523034", "0.65506756", "0.65114737", "0.65097904", "0.6494804", "0.64884955", "0.6487379", "0.64851904", "0.64851904", "0.6483137", "0.6482328", "0.6479143", "0.64691234", "0.6461995", "0.64569384", "0.64521354", "0.6448759", "0.64414567", "0.6431104", "0.64252645", "0.64070183", "0.6395104", "0.63894117", "0.6370124", "0.63631624", "0.6355686", "0.63437593", "0.633893", "0.63381565", "0.6337373", "0.63356066", "0.63323957", "0.6331978", "0.6327127", "0.63215697", "0.63161373", "0.6305079", "0.6302775", "0.63025963", "0.63004816", "0.62810355", "0.6278762", "0.62773335", "0.6266512", "0.6265272", "0.62540835", "0.62469125", "0.6246385", "0.6236299", "0.6230946", "0.6226481", "0.6226216", "0.6225922" ]
0.0
-1
$FF: renamed from: a (gI, boolean) java.util.List
public List method_2154(class_1069 param1, boolean param2) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo13375a(boolean z, int i, int i2, List<C15929a> list);", "void mo100444b(List<C40429b> list);", "void mo69875a(List<Aweme> list, boolean z);", "public boolean isList();", "public boolean isList();", "public boolean isListable();", "public abstract void mo56923b(List<C4122e> list);", "boolean getIsList();", "boolean getIsList();", "@VTID(38)\n boolean getList();", "public abstract void mo56920a(List<C4122e> list);", "public boolean[] getBooleanList();", "ListType createListType();", "private static interface T {@Symbolic Term.List t();}", "boolean m6609a(List<Log> list);", "Listof<X> toList();", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "public boolean isList() {\n // This method could not be decompiled.\n // \n // Original Bytecode:\n // \n // 0: sastore \n // 1: ladd \n // LocalVariableTable:\n // Start Length Slot Name Signature\n // ----- ------ ---- ---- ------------------------------------------\n // 0 2 0 this Lcom/sun/xml/xsom/impl/ListSimpleTypeImpl;\n // \n // The error that occurred was:\n // \n // java.lang.ArrayIndexOutOfBoundsException\n // \n throw new IllegalStateException(\"An error occurred while decompiling this method.\");\n }", "ListValue createListValue();", "abstract void makeList();", "void mo54419a(List<String> list);", "Object getTolist();", "boolean hasList();", "public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}", "public XSListSimpleType asList() {\n // This method could not be decompiled.\n // \n // Original Bytecode:\n // \n // 0: idiv \n // 1: laload \n // LocalVariableTable:\n // Start Length Slot Name Signature\n // ----- ------ ---- ---- ------------------------------------------\n // 0 2 0 this Lcom/sun/xml/xsom/impl/ListSimpleTypeImpl;\n // \n // The error that occurred was:\n // \n // java.lang.ArrayIndexOutOfBoundsException\n // \n throw new IllegalStateException(\"An error occurred while decompiling this method.\");\n }", "List<C1111j> mo5873b();", "private static void addToList(String paramString1, String paramString2, boolean paramBoolean) {\n }", "protected abstract IList _listValue(IScope scope, IType contentsType, boolean cast);", "interface a {\n Object a();\n\n boolean b();\n\n List<Object> c();\n}", "public boolean isInList();", "private static List<C31644f<?, R>> m102869a() {\n return new ArrayList<>();\n }", "public ArrayList a(boolean bl2) {\n synchronized (this) {\n ArrayList<Object> arrayList = new ArrayList<Object>();\n Object object = this.a;\n boolean bl3 = true;\n if (object != null) {\n object = ((cv)object).a(bl3);\n arrayList.addAll((Collection<Object>)object);\n }\n object = cz.b;\n synchronized (object) {\n Object object2 = cz.b;\n String string2 = ((cv)this).b;\n object2 = object2.get(string2);\n object2 = (cv)object2;\n if (object2 != null) {\n boolean bl4;\n Object object3 = ((cv)object2).a(bl3);\n object3 = ((ArrayList)object3).iterator();\n while (bl4 = object3.hasNext()) {\n int n10;\n object2 = object3.next();\n int n11 = arrayList.indexOf(object2 = (String)object2);\n if (n11 != (n10 = -1)) continue;\n arrayList.add(object2);\n }\n object3 = ((cv)this).b;\n arrayList.remove(object3);\n object3 = ((cv)this).b;\n arrayList.add(object3);\n }\n return arrayList;\n }\n }\n }", "OpFList createOpFList();", "public List<Boolean> getBooleanList(final String key) {\n return getBooleanList(key, new ArrayList<>());\n }", "public interface DList {\n}", "public void genLists() {\n\t}", "public abstract List toNameValueList();", "@java.lang.Override\n public boolean getIsList() {\n return isList_;\n }", "@java.lang.Override\n public boolean getIsList() {\n return isList_;\n }", "public List<New> list();", "static /* synthetic */ Iterable m6171a(List list) {\n $jacocoInit()[107] = true;\n return list;\n }", "java.util.List<protocol.Data.Friend.FriendItem> \n getFriendList();", "void mo7380a(C1320b bVar, List<String> list) throws RemoteException;", "void mo1638a(long j, long j2, List list, ayp ayp);", "@Override\n\tpublic void acheter(List<Object> la) {\n\t\t\n\t}", "protected List getList() {\n/* 88 */ return (List)getCollection();\n/* */ }", "@java.lang.Override\n public boolean getIsList() {\n return isList_;\n }", "@java.lang.Override\n public boolean getIsList() {\n return isList_;\n }", "public abstract List<T> mo2625k();", "List<?> getList();", "public Builder setIsList(boolean value) {\n\n isList_ = value;\n bitField0_ |= 0x00000004;\n onChanged();\n return this;\n }", "void mo29842a(IObjectWrapper iObjectWrapper, zzatk zzatk, List<String> list) throws RemoteException;", "public void m(List<?> list) {\n\t}", "public final io.reactivex.i<Pair<j, Boolean>> apply(List<j> list) {\n kotlin.jvm.internal.h.e(list, \"it\");\n for (Object next : list) {\n Object obj;\n if (((j) next).aAt().getId() == com.iqoption.core.f.RQ().Dr().getUserId()) {\n obj = 1;\n continue;\n } else {\n obj = null;\n continue;\n }\n if (obj != null) {\n break;\n }\n }\n Object next2 = null;\n j jVar = (j) next2;\n if (jVar != null) {\n return io.reactivex.i.bZ(kotlin.j.D(jVar, Boolean.valueOf(this.dlr.a(this.dls, list))));\n }\n return io.reactivex.i.aWe();\n }", "public Builder setIsList(boolean value) {\n\n isList_ = value;\n bitField0_ |= 0x00000008;\n onChanged();\n return this;\n }", "public interface a {\n void a(int i, List<String> list, boolean z, long j, String str, String str2, String str3);\n }", "java.util.List<com.mwr.jdiesel.api.Protobuf.Message.Argument> \n getElementList();", "private void addToList (IGameState state, MoveEvaluation m) {\n\t\tlist.append(new Pair(state.copy(), m));\n\t}", "@Override\n\tpublic void visit(ValueListExpression arg0) {\n\t\t\n\t}", "@Test public void asListSimple() {\n @SuppressWarnings(\"null\") final @NotNull List<Integer> is = as.list(new int @NotNull [] { 12, 13, 14 });\n azzert.that(is.get(0), is(fluent.ly.box.it(12)));\n azzert.that(is.get(1), is(fluent.ly.box.it(13)));\n azzert.that(is.get(2), is(fluent.ly.box.it(14)));\n azzert.that(is.size(), is(3));\n }", "List<C1111j> mo5868a();", "public BuildListFlag(ArrayList<Direction> buildList, Worker worker){\n super(buildList, worker);\n this.type = ClientMessageType.BUILD_LIST_FLAG;\n }", "void mo9148a(int i, ArrayList<C0889x> arrayList);", "java.util.List<? extends iet.distributed.telemetry.FeatureOrBuilder> \n getFeatureOrBuilderList();", "@Test\r\n\tpublic void testListArg() {\r\n\t\tAssert.assertEquals(\"test[(`a,`b,`c)]\", new FunctionImpl.FunctionBuilderImpl(\"test\").param(SymbolValue.froms(\"a\", \"b\", \"c\")).build().toQ());\r\n\t}", "@ApiStatus.Internal\n default boolean isListable() {\n \n return false;\n }", "List <JAVATYPE> convertList(List<JAVATYPE> oldList, final METATYPE meta);", "void mo29841a(IObjectWrapper iObjectWrapper, zzaiq zzaiq, List<zzaiw> list) throws RemoteException;", "java.util.List<? extends protocol.Data.Friend.FriendItemOrBuilder> \n getFriendOrBuilderList();", "java.util.List<People>\n getFriendListList();", "public void bar(java.util.List<java.lang.Integer> foo) { return; }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public R visit(com.biosimilarity.lift.lib.scalar.Absyn.Listed p, A arg)\n {\n\n for (Expression x : p.listexpression_) {\n }\n\n return null;\n }", "List<Status> mo9947a();", "@DSComment(\"From safe class list\")\n @DSSafe(DSCat.SAFE_LIST)\n @DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2013-12-30 12:56:09.367 -0500\", hash_original_method = \"4A1605B03FE1E22048A20B9E05E481A5\", hash_generated_method = \"4396D2BAEFB73347858E563F022F81BC\")\n \n@Override\n public String toString() {\n return getClass().getName() + '(' + getName() + ')';\n }", "private static Type getListType() {\n return getListTypeToken().getType();\n }", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public interface ListConverterList<From,To> extends Converter<List<From>,List<To>> {\r\n}", "boolean[] bitwiseChangeList();", "public final void accept(List<? extends com.iqoption.fragment.c.a.a.j> list) {\n a aVar = this.dhx.dhv.dhu;\n kotlin.jvm.internal.i.e(list, \"list\");\n aVar.aU(list);\n }", "java.util.List<? extends com.rpg.framework.database.Protocol.QuestOrBuilder> \n getQuestOrBuilderList();", "abstract List<T> getReuslt();", "public final void a(java.util.List<com.bytedance.ad.symphony.model.config.AdConfig> r13, android.util.SparseArray<com.bytedance.ad.symphony.provider.a.C0060a> r14, java.lang.Class<? extends com.bytedance.ad.symphony.a.a> r15) {\n /*\n r12 = this;\n boolean r0 = r12.l\n r1 = 0\n if (r0 == 0) goto L_0x000a\n r12.l = r1\n r12.c()\n L_0x000a:\n if (r13 == 0) goto L_0x0143\n boolean r0 = r13.isEmpty()\n if (r0 == 0) goto L_0x0014\n goto L_0x0143\n L_0x0014:\n boolean r0 = r12.m\n if (r0 != 0) goto L_0x0019\n return\n L_0x0019:\n java.lang.Object r0 = r12.j\n monitor-enter(r0)\n java.util.ArrayList r2 = new java.util.ArrayList // Catch:{ all -> 0x0140 }\n r2.<init>(r13) // Catch:{ all -> 0x0140 }\n java.util.Iterator r2 = r2.iterator() // Catch:{ all -> 0x0140 }\n L_0x0025:\n boolean r3 = r2.hasNext() // Catch:{ all -> 0x0140 }\n if (r3 == 0) goto L_0x00c7\n java.lang.Object r3 = r2.next() // Catch:{ all -> 0x0140 }\n com.bytedance.ad.symphony.model.config.AdConfig r3 = (com.bytedance.ad.symphony.model.config.AdConfig) r3 // Catch:{ all -> 0x0140 }\n if (r3 == 0) goto L_0x0025\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r4 = r12.f7552c // Catch:{ all -> 0x0140 }\n int r5 = r3.f7654a // Catch:{ all -> 0x0140 }\n java.lang.Integer r5 = java.lang.Integer.valueOf(r5) // Catch:{ all -> 0x0140 }\n boolean r4 = r4.containsKey(r5) // Catch:{ all -> 0x0140 }\n if (r4 != 0) goto L_0x00b4\n android.content.Context r4 = r12.f7555f // Catch:{ all -> 0x0140 }\n r5 = 0\n java.lang.String r6 = \"\"\n if (r3 == 0) goto L_0x005b\n if (r14 == 0) goto L_0x005b\n int r7 = r3.f7654a // Catch:{ Exception -> 0x0088 }\n int r7 = com.bytedance.ad.symphony.provider.a.getRealProviderId(r7) // Catch:{ Exception -> 0x0088 }\n java.lang.Object r7 = r14.get(r7) // Catch:{ Exception -> 0x0088 }\n com.bytedance.ad.symphony.provider.a$a r7 = (com.bytedance.ad.symphony.provider.a.C0060a) r7 // Catch:{ Exception -> 0x0088 }\n if (r7 == 0) goto L_0x005b\n java.lang.String r7 = r7.f7679c // Catch:{ Exception -> 0x0088 }\n r6 = r7\n L_0x005b:\n boolean r7 = com.bytedance.common.utility.StringUtils.isEmpty(r6) // Catch:{ Exception -> 0x0088 }\n if (r7 == 0) goto L_0x0062\n goto L_0x0025\n L_0x0062:\n java.lang.Class r7 = java.lang.Class.forName(r6) // Catch:{ Exception -> 0x0088 }\n r8 = 3\n java.lang.Class[] r9 = new java.lang.Class[r8] // Catch:{ Exception -> 0x0088 }\n java.lang.Class<android.content.Context> r10 = android.content.Context.class\n r9[r1] = r10 // Catch:{ Exception -> 0x0088 }\n java.lang.Class<com.bytedance.ad.symphony.model.config.AdConfig> r10 = com.bytedance.ad.symphony.model.config.AdConfig.class\n r11 = 1\n r9[r11] = r10 // Catch:{ Exception -> 0x0088 }\n r10 = 2\n r9[r10] = r15 // Catch:{ Exception -> 0x0088 }\n java.lang.reflect.Constructor r7 = r7.getConstructor(r9) // Catch:{ Exception -> 0x0088 }\n java.lang.Object[] r8 = new java.lang.Object[r8] // Catch:{ Exception -> 0x0088 }\n r8[r1] = r4 // Catch:{ Exception -> 0x0088 }\n r8[r11] = r3 // Catch:{ Exception -> 0x0088 }\n r8[r10] = r12 // Catch:{ Exception -> 0x0088 }\n java.lang.Object r4 = r7.newInstance(r8) // Catch:{ Exception -> 0x0088 }\n com.bytedance.ad.symphony.provider.a r4 = (com.bytedance.ad.symphony.provider.a) r4 // Catch:{ Exception -> 0x0088 }\n goto L_0x0096\n L_0x0088:\n r12.a() // Catch:{ all -> 0x0140 }\n java.lang.StringBuilder r4 = new java.lang.StringBuilder // Catch:{ all -> 0x0140 }\n java.lang.String r7 = \"createProvider, className-->\"\n r4.<init>(r7) // Catch:{ all -> 0x0140 }\n r4.append(r6) // Catch:{ all -> 0x0140 }\n r4 = r5\n L_0x0096:\n if (r4 == 0) goto L_0x0025\n r12.a() // Catch:{ all -> 0x0140 }\n java.lang.StringBuilder r5 = new java.lang.StringBuilder // Catch:{ all -> 0x0140 }\n java.lang.String r6 = \"createProvider, providerId-->\"\n r5.<init>(r6) // Catch:{ all -> 0x0140 }\n int r6 = r3.f7654a // Catch:{ all -> 0x0140 }\n r5.append(r6) // Catch:{ all -> 0x0140 }\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r5 = r12.f7552c // Catch:{ all -> 0x0140 }\n int r3 = r3.f7654a // Catch:{ all -> 0x0140 }\n java.lang.Integer r3 = java.lang.Integer.valueOf(r3) // Catch:{ all -> 0x0140 }\n r5.put(r3, r4) // Catch:{ all -> 0x0140 }\n goto L_0x0025\n L_0x00b4:\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r4 = r12.f7552c // Catch:{ all -> 0x0140 }\n int r5 = r3.f7654a // Catch:{ all -> 0x0140 }\n java.lang.Integer r5 = java.lang.Integer.valueOf(r5) // Catch:{ all -> 0x0140 }\n java.lang.Object r4 = r4.get(r5) // Catch:{ all -> 0x0140 }\n com.bytedance.ad.symphony.provider.b r4 = (com.bytedance.ad.symphony.provider.b) r4 // Catch:{ all -> 0x0140 }\n r4.setAdConfig(r3) // Catch:{ all -> 0x0140 }\n goto L_0x0025\n L_0x00c7:\n r12.a() // Catch:{ all -> 0x0140 }\n java.lang.StringBuilder r14 = new java.lang.StringBuilder // Catch:{ all -> 0x0140 }\n java.lang.String r15 = \"initConfig, providers created, size-->\"\n r14.<init>(r15) // Catch:{ all -> 0x0140 }\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r15 = r12.f7552c // Catch:{ all -> 0x0140 }\n if (r15 != 0) goto L_0x00d6\n goto L_0x00dc\n L_0x00d6:\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r15 = r12.f7552c // Catch:{ all -> 0x0140 }\n int r1 = r15.size() // Catch:{ all -> 0x0140 }\n L_0x00dc:\n r14.append(r1) // Catch:{ all -> 0x0140 }\n monitor-exit(r0) // Catch:{ all -> 0x0140 }\n com.bytedance.ad.symphony.c.a r14 = r12.h\n if (r14 == 0) goto L_0x013f\n java.util.ArrayList r14 = new java.util.ArrayList\n r14.<init>()\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r15 = r12.f7552c\n java.util.Set r15 = r15.keySet()\n java.util.Iterator r15 = r15.iterator()\n L_0x00f3:\n boolean r0 = r15.hasNext()\n if (r0 == 0) goto L_0x0103\n java.lang.Object r0 = r15.next()\n java.lang.Integer r0 = (java.lang.Integer) r0\n r14.add(r0)\n goto L_0x00f3\n L_0x0103:\n java.lang.Boolean r14 = r12.k\n boolean r14 = r14.booleanValue()\n if (r14 == 0) goto L_0x012f\n java.lang.Boolean r14 = r12.k\n monitor-enter(r14)\n java.lang.Boolean r15 = r12.k // Catch:{ all -> 0x012c }\n boolean r15 = r15.booleanValue() // Catch:{ all -> 0x012c }\n if (r15 == 0) goto L_0x012a\n java.util.Map<java.lang.Integer, com.bytedance.ad.symphony.provider.b<AD>> r15 = r12.f7552c // Catch:{ all -> 0x012c }\n if (r15 == 0) goto L_0x012a\n java.lang.Boolean r13 = java.lang.Boolean.FALSE // Catch:{ all -> 0x012c }\n r12.k = r13 // Catch:{ all -> 0x012c }\n android.os.Handler r13 = r12.f7551b // Catch:{ all -> 0x012c }\n com.bytedance.ad.symphony.a.a.a$3 r15 = new com.bytedance.ad.symphony.a.a.a$3 // Catch:{ all -> 0x012c }\n r15.<init>() // Catch:{ all -> 0x012c }\n r13.post(r15) // Catch:{ all -> 0x012c }\n monitor-exit(r14) // Catch:{ all -> 0x012c }\n return\n L_0x012a:\n monitor-exit(r14) // Catch:{ all -> 0x012c }\n goto L_0x012f\n L_0x012c:\n r13 = move-exception\n monitor-exit(r14) // Catch:{ all -> 0x012c }\n throw r13\n L_0x012f:\n boolean r13 = com.bytedance.ad.symphony.g.d.a(r13)\n if (r13 != 0) goto L_0x013f\n android.os.Handler r13 = r12.f7551b\n com.bytedance.ad.symphony.a.a.a$4 r14 = new com.bytedance.ad.symphony.a.a.a$4\n r14.<init>()\n r13.post(r14)\n L_0x013f:\n return\n L_0x0140:\n r13 = move-exception\n monitor-exit(r0) // Catch:{ all -> 0x0140 }\n throw r13\n L_0x0143:\n r12.a()\n return\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.bytedance.ad.symphony.a.a.a.a(java.util.List, android.util.SparseArray, java.lang.Class):void\");\n }", "int mo1635a(long j, List list);", "public interface C40453c {\n /* renamed from: a */\n void mo100442a(C40429b bVar);\n\n /* renamed from: a */\n void mo100443a(List<String> list);\n\n /* renamed from: b */\n void mo100444b(List<C40429b> list);\n}", "public interface IListElementOperations extends IMode {\n\n /**\n * @return true if the operation does not return value\n */\n public boolean isStatment();\n}", "List<E> list(String field, String contains);", "@ZenCodeType.Caster\n @ZenCodeType.Method\n default List<IData> asList() {\n \n return notSupportedCast(\"IData[]\");\n }", "List<C1111j> mo5869a(int i);", "@Override\n public boolean isListFactory() {\n return true;\n }", "public interface C27442s {\n /* renamed from: d */\n List<EffectPointModel> mo70331d();\n}", "void mo100443a(List<String> list);", "public abstract List<C41717j> mo70725h(String str);", "@Parameters\n\tpublic static List<Object[]> data() {\n\t\tfinal Object[][] data = new Object[][] {\n\t\t\t\t{ true, new Operator[] { TRUE } },\n\t\t\t\t{ true, new Operator[] { FALSE } },\n\t\t\t\t{ true, new Operator[] { FALSE, TRUE } },\n\t\t\t\t{ false, new Operator[] { TRUE, FALSE, TRUE } },\n\t\t\t\t{ false, new Operator[] { TRUE, TRUE, FALSE } },\n\t\t};\n\t\treturn Arrays.asList(data);\n\t}", "com.google.protobuf.ProtocolStringList\n getListList();", "public static boolean typeList(PsiBuilder b, int l) {\n if (!recursion_guard_(b, l, \"typeList\")) return false;\n boolean r;\n Marker m = enter_section_(b, l, _NONE_, TYPE_LIST, \"<type list>\");\n r = typeList_0(b, l + 1);\n r = r && typeList_1(b, l + 1);\n exit_section_(b, l, m, r, false, null);\n return r;\n }", "public interface se {\n void a(List<POI> list);\n\n boolean a();\n\n void b();\n\n boolean c();\n\n List<POI> d();\n\n POI e();\n\n POI f();\n}", "List<IFeature> getFeatureList();", "interface List extends Follow {\n @Out Network[] networks();\n\n /**\n * Sets the maximum number of networks to return. If not specified all the networks are returned.\n */\n @In Integer max();\n\n /**\n * A query string used to restrict the returned networks.\n */\n @In String search();\n\n /**\n * Indicates if the search performed using the `search` parameter should be performed taking case into\n * account. The default value is `true`, which means that case is taken into account. If you want to search\n * ignoring case set it to `false`.\n */\n @In Boolean caseSensitive();\n }", "private Lists() { }" ]
[ "0.64870757", "0.64037424", "0.6382275", "0.6351526", "0.6351526", "0.6211182", "0.62095994", "0.6199849", "0.6199849", "0.617992", "0.6097201", "0.60941887", "0.5944554", "0.5907852", "0.5907323", "0.5890358", "0.5859307", "0.5844528", "0.5829173", "0.5806536", "0.5766544", "0.5749565", "0.57457083", "0.574495", "0.5686376", "0.5657833", "0.56498736", "0.5644174", "0.5640563", "0.5613648", "0.56058085", "0.5591823", "0.5576743", "0.55671877", "0.5566081", "0.55602527", "0.5555718", "0.55307275", "0.55307275", "0.5518732", "0.55161744", "0.55111516", "0.55056787", "0.54888195", "0.5475299", "0.5462981", "0.5450097", "0.5450097", "0.54499286", "0.54474974", "0.5431351", "0.542967", "0.5426668", "0.542551", "0.54244655", "0.5424055", "0.541104", "0.54071367", "0.54032767", "0.5399337", "0.5391294", "0.5387544", "0.53859794", "0.5385077", "0.53748715", "0.5372653", "0.5367758", "0.53657615", "0.53563076", "0.53407717", "0.5340596", "0.5340287", "0.5330696", "0.5329219", "0.53286815", "0.53286064", "0.5327725", "0.5325238", "0.5323373", "0.5323034", "0.5321102", "0.5316232", "0.53147155", "0.53111506", "0.5311022", "0.53104347", "0.5308375", "0.52966803", "0.5287166", "0.5286797", "0.5285537", "0.5281742", "0.52815413", "0.52809864", "0.5277273", "0.5271223", "0.5270527", "0.5267457", "0.52660036", "0.52650565" ]
0.5747687
22
$FF: renamed from: a (sa, boolean) void
public void method_2116(class_689 param1, boolean param2) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public abstract boolean a();", "void mo6661a(boolean z);", "void mo98208a(boolean z);", "void mo1488a(boolean z);", "abstract void mo956a(boolean z);", "void mo99838a(boolean z);", "void boolean1(boolean a);", "void mo21069a(boolean z);", "void mo64153a(boolean z);", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "void mo3305a(boolean z);", "void mo1492b(boolean z);", "void mo197b(boolean z);", "public void b(boolean paramBoolean)\r\n/* 603: */ {\r\n/* 604:601 */ this.l = paramBoolean;\r\n/* 605: */ }", "public void am(boolean z) {\n }", "void mo9701a(boolean z);", "public void a(boolean paramBoolean)\r\n/* 593: */ {\r\n/* 594:593 */ this.k = paramBoolean;\r\n/* 595: */ }", "final void a(boolean paramBoolean) {\n/* 14387 */ this.d = true;\n/* */ }", "void mo12636a(boolean z);", "public interface AbstractC10485b {\n /* renamed from: a */\n void mo64153a(boolean z);\n }", "public boolean a()\r\n {\r\n return false;\r\n }", "void mo54420a(boolean z, boolean z2);", "public void b(boolean paramBoolean)\r\n/* 184: */ {\r\n/* 185:183 */ this.g = paramBoolean;\r\n/* 186: */ }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public void ak(boolean z) {\n }", "@Override\n\tpublic void a() {\n\t\t\n\t}", "public void method_217(boolean var1) {}", "public boolean a()\n {\n return true;\n }", "public interface a {\n void cp(boolean z);\n }", "@Nullable\n /* renamed from: a */\n public abstract C4891ao mo18474a(Object obj, boolean z);", "public void a() {\r\n }", "public void ae(boolean z) {\n }", "void mo54415a(int i, boolean z);", "public void a(boolean paramBoolean)\r\n/* 80: */ {\r\n/* 81: 83 */ this.splash = paramBoolean;\r\n/* 82: */ }", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "public abstract void mo32006dL(boolean z);", "public interface m {\n void a(boolean z);\n}", "public void a() {\n }", "public void a() {\n }", "public abstract void mo9806a(int i, boolean z);", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public abstract boolean mo66253b();", "public final void mo5689a(boolean z) {\n }", "void mo717a(boolean z) throws RemoteException;", "void mo28194a();", "public abstract void mo9254f(boolean z);", "public boolean method_2153(boolean param1) {\r\n // $FF: Couldn't be decompiled\r\n }", "public final void mo12411a(boolean z) {\n }", "public interface C10555f {\n /* renamed from: es */\n void mo22049es(boolean z);\n }", "public void ai(boolean z) {\n }", "public void mo97903a(boolean z) {\n }", "void b();", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "public boolean isVoid()\r\n/* 146: */ {\r\n/* 147:177 */ return false;\r\n/* 148: */ }", "public void b() {\r\n }", "protected void a(int paramInt1, int paramInt2, boolean paramBoolean, yz paramyz) {}", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "public abstract boolean mo9234ar();", "public abstract boolean a(C c);", "public abstract void mo4368a(int i, boolean z);", "void mo22049es(boolean z);", "public void b() {\n }", "public void b() {\n }", "public interface a {\n void a();\n }", "public interface a {\n void a();\n }", "public abstract void mo70713b();", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "public abstract void mo70702a(C30989b c30989b);", "void mo28742b(boolean z, int i);", "public boolean a(World paramaqu, BlockPosition paramdt, Block parambec, boolean paramBoolean)\r\n/* 67: */ {\r\n/* 68: 83 */ return true;\r\n/* 69: */ }", "void mo21071b(boolean z);", "public void mo97905b(boolean z) {\n }", "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public abstract boolean a(e parame, b paramb, int paramInt1, int paramInt2);", "void mo41083a();", "public abstract void m15813a();", "void mo80452a();", "void mo28309a(boolean z, int i);", "void mo13374a(boolean z, int i, int i2);", "protected boolean func_70814_o() { return true; }", "@Override // com.tapjoy.internal.gt\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final void a(android.app.Activity r6) {\n /*\n // Method dump skipped, instructions count: 106\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tapjoy.internal.fp.a(android.app.Activity):void\");\n }", "@Override\r\n\tpublic void a1() {\n\t\t\r\n\t}", "@Override\n public void b() {\n }", "@Override\n public void func_104112_b() {\n \n }", "interface C4483e {\n /* renamed from: a */\n boolean mo34114a();\n}", "public void method_2249(boolean param1, class_81 param2) {\r\n // $FF: Couldn't be decompiled\r\n }", "public void o_()\r\n/* 533: */ {\r\n/* 534:539 */ this.e = true;\r\n/* 535: */ }", "public interface C1061nc extends IInterface {\n /* renamed from: a */\n String mo2800a();\n\n /* renamed from: a */\n String mo2801a(String str);\n\n /* renamed from: a */\n void mo2802a(String str, boolean z);\n\n /* renamed from: a */\n boolean mo2803a(boolean z);\n}", "void mo13368a();", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "public void m23075a() {\n }", "public abstract java.lang.Object a ( ) {\n/* .annotation system Ldalvik/annotation/Signature; */\n/* value = { */\n/* \"()TT;\" */\n/* } */\n}", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void m1864a() {\r\n }", "public final boolean func_boolean_a(int var1, int var2) {\n if (this.func_boolean_b(var1, var2)) {\n return true;\n } else if (var2 != 53 && var1 != 8) {\n if (var2 == -8) {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)0);\n return true;\n } else {\n return true;\n }\n } else {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)1);\n return true;\n }\n }", "public interface C4051c {\n /* renamed from: a */\n boolean mo23707a();\n}" ]
[ "0.73093957", "0.7170463", "0.7088861", "0.7062704", "0.706256", "0.7039611", "0.7035307", "0.70276725", "0.69581157", "0.6934835", "0.68952364", "0.68877256", "0.68826896", "0.6800045", "0.67654747", "0.6728229", "0.6715317", "0.66885346", "0.66693896", "0.6667515", "0.6666887", "0.66650987", "0.6634629", "0.66343045", "0.6580035", "0.6565522", "0.65617996", "0.6553762", "0.6547811", "0.64992714", "0.64822304", "0.64810437", "0.6470867", "0.64678836", "0.6449091", "0.64440644", "0.6443981", "0.6435322", "0.63839215", "0.6383332", "0.63761884", "0.6373269", "0.6373269", "0.6369775", "0.6351991", "0.63224953", "0.6310495", "0.6298926", "0.6279803", "0.6278391", "0.6271438", "0.6267507", "0.62615263", "0.62607896", "0.62211436", "0.6213518", "0.62067395", "0.6199376", "0.6198012", "0.61942154", "0.61713797", "0.61698085", "0.6164276", "0.61480623", "0.61380035", "0.61194843", "0.61194843", "0.6118053", "0.6118053", "0.6116397", "0.6109247", "0.61048657", "0.6104701", "0.6098772", "0.6095888", "0.6095758", "0.60941887", "0.6091858", "0.6091333", "0.60774964", "0.605857", "0.60572696", "0.6055515", "0.6046585", "0.60444075", "0.6043507", "0.6041785", "0.6040347", "0.60401016", "0.603686", "0.60349655", "0.6031992", "0.60305953", "0.6026146", "0.6023209", "0.6017654", "0.6016471", "0.6011225", "0.60065806", "0.6003785", "0.60006505" ]
0.0
-1
$FF: renamed from: j () gG
protected class_25 method_2044() { class_26 var1 = this.field_1823.method_127(this.field_1820); class_1665 var10001 = new class_1665; var10001.method_9187(this, var1, this.field_1820.method_6164()); this.field_1855 = var10001; return this.field_1855; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void j() {\n }", "protected float j()\r\n/* 67: */ {\r\n/* 68: 80 */ return 1.5F;\r\n/* 69: */ }", "public int func_70297_j_()\n/* */ {\n/* 71 */ return 64;\n/* */ }", "public abstract void mo2624j();", "void mo1941j();", "void mo24142a(long j);", "void mo30275a(long j);", "public abstract void mo4383c(long j);", "void mo18324a(C7260j jVar);", "void mo30290d(long j);", "public void mo21785J() {\n }", "public final void zzjk() {\n }", "void mo57277b();", "public abstract C7035a mo24417b(long j);", "public abstract void mo9243b(long j);", "void mo21076g();", "void mo5870a(C1111j jVar);", "dkj mo4367a(dkk dkk);", "public final void mo7668gn(long j) {\n }", "public final void mo7668gn(long j) {\n }", "anx j6(asg r27, long r28) {\n /*\n r26 = this;\n r0 = r27;\n r8 = r0.j6;\t Catch:{ DataFormatException -> 0x01db }\n r12 = 0;\n r4 = 0;\n r4 = (byte[]) r4;\t Catch:{ DataFormatException -> 0x01db }\n r23 = -1;\n r22 = 0;\n r13 = r12;\n r6 = r28;\n L_0x000f:\n r9 = 0;\n r10 = 20;\n r5 = r26;\n r11 = r27;\n r5.j6(r6, r8, r9, r10, r11);\t Catch:{ DataFormatException -> 0x004d }\n r5 = 0;\n r5 = r8[r5];\t Catch:{ DataFormatException -> 0x004d }\n r12 = r5 & 255;\n r5 = r12 >> 4;\n r9 = r5 & 7;\n r5 = r12 & 15;\n r10 = (long) r5;\t Catch:{ DataFormatException -> 0x004d }\n r5 = 4;\n r14 = 1;\n r24 = r5;\n r5 = r12;\n r12 = r24;\n L_0x002c:\n r5 = r5 & 128;\n if (r5 != 0) goto L_0x0072;\n L_0x0030:\n switch(r9) {\n case 1: goto L_0x0087;\n case 2: goto L_0x0087;\n case 3: goto L_0x0087;\n case 4: goto L_0x0087;\n case 5: goto L_0x0033;\n case 6: goto L_0x00c5;\n case 7: goto L_0x011d;\n default: goto L_0x0033;\n };\t Catch:{ DataFormatException -> 0x004d }\n L_0x0033:\n r4 = new java.io.IOException;\t Catch:{ DataFormatException -> 0x004d }\n r5 = org.eclipse.jgit.JGitText.j6();\t Catch:{ DataFormatException -> 0x004d }\n r5 = r5.unknownObjectType;\t Catch:{ DataFormatException -> 0x004d }\n r8 = 1;\n r8 = new java.lang.Object[r8];\t Catch:{ DataFormatException -> 0x004d }\n r10 = 0;\n r9 = java.lang.Integer.valueOf(r9);\t Catch:{ DataFormatException -> 0x004d }\n r8[r10] = r9;\t Catch:{ DataFormatException -> 0x004d }\n r5 = java.text.MessageFormat.format(r5, r8);\t Catch:{ DataFormatException -> 0x004d }\n r4.<init>(r5);\t Catch:{ DataFormatException -> 0x004d }\n throw r4;\t Catch:{ DataFormatException -> 0x004d }\n L_0x004d:\n r4 = move-exception;\n L_0x004e:\n r5 = new ala;\n r8 = org.eclipse.jgit.JGitText.j6();\n r8 = r8.objectAtHasBadZlibStream;\n r9 = 2;\n r9 = new java.lang.Object[r9];\n r10 = 0;\n r6 = java.lang.Long.valueOf(r6);\n r9[r10] = r6;\n r6 = 1;\n r7 = r26.j6();\n r9[r6] = r7;\n r6 = java.text.MessageFormat.format(r8, r9);\n r5.<init>(r6);\n r5.initCause(r4);\n throw r5;\n L_0x0072:\n r5 = r14 + 1;\n r14 = r8[r14];\t Catch:{ DataFormatException -> 0x004d }\n r0 = r14 & 255;\n r16 = r0;\n r14 = r16 & 127;\n r14 = r14 << r12;\n r14 = (long) r14;\t Catch:{ DataFormatException -> 0x004d }\n r14 = r14 + r10;\n r10 = r12 + 7;\n r12 = r10;\n r10 = r14;\n r14 = r5;\n r5 = r16;\n goto L_0x002c;\n L_0x0087:\n r5 = r27.VH();\t Catch:{ DataFormatException -> 0x004d }\n r0 = (long) r5;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r5 = (r10 > r16 ? 1 : (r10 == r16 ? 0 : -1));\n if (r5 >= 0) goto L_0x009d;\n L_0x0092:\n r4 = (long) r14;\t Catch:{ DataFormatException -> 0x004d }\n r4 = r4 + r6;\n r8 = (int) r10;\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r27;\n r4 = r0.j6(r4, r8, r1);\t Catch:{ DataFormatException -> 0x004d }\n L_0x009d:\n if (r13 == 0) goto L_0x00ae;\n L_0x009f:\n r10 = r22;\n r8 = r4;\n r4 = r13;\n L_0x00a3:\n if (r8 != 0) goto L_0x01e0;\n L_0x00a5:\n r0 = r26;\n r1 = r27;\n r8 = r4.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n L_0x00ad:\n return r8;\n L_0x00ae:\n if (r4 == 0) goto L_0x00b6;\n L_0x00b0:\n r8 = new anx$a;\t Catch:{ DataFormatException -> 0x004d }\n r8.<init>(r9, r4);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x00b6:\n r8 = new arg;\t Catch:{ DataFormatException -> 0x004d }\n r0 = r27;\n r0 = r0.DW;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r12 = r6;\n r15 = r26;\n r8.<init>(r9, r10, r12, r14, r15, r16);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x00c5:\n r17 = r14 + 1;\n r5 = r8[r14];\t Catch:{ DataFormatException -> 0x004d }\n r5 = r5 & 255;\n r9 = r5 & 127;\n r14 = (long) r9;\t Catch:{ DataFormatException -> 0x004d }\n L_0x00ce:\n r5 = r5 & 128;\n if (r5 != 0) goto L_0x00eb;\n L_0x00d2:\n r18 = r6 - r14;\n r12 = new aro$a;\t Catch:{ DataFormatException -> 0x004d }\n r0 = (int) r10;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r14 = r6;\n r12.<init>(r13, r14, r16, r17, r18);\t Catch:{ DataFormatException -> 0x004d }\n r5 = r12.FH;\t Catch:{ DataFormatException -> 0x004d }\n r14 = (long) r5;\t Catch:{ DataFormatException -> 0x004d }\n r5 = (r10 > r14 ? 1 : (r10 == r14 ? 0 : -1));\n if (r5 == 0) goto L_0x0102;\n L_0x00e4:\n r10 = r22;\n r9 = r23;\n r8 = r4;\n r4 = r12;\n goto L_0x00a3;\n L_0x00eb:\n r18 = 1;\n r14 = r14 + r18;\n r5 = r17 + 1;\n r9 = r8[r17];\t Catch:{ DataFormatException -> 0x004d }\n r9 = r9 & 255;\n r12 = 7;\n r14 = r14 << r12;\n r12 = r9 & 127;\n r0 = (long) r12;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r14 = r14 + r16;\n r17 = r5;\n r5 = r9;\n goto L_0x00ce;\n L_0x0102:\n r5 = r27.Hw();\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r18;\n r5 = r5.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n if (r5 == 0) goto L_0x0118;\n L_0x0110:\n r9 = r5.DW;\t Catch:{ DataFormatException -> 0x004d }\n r4 = r5.j6;\t Catch:{ DataFormatException -> 0x004d }\n r10 = 1;\n r8 = r4;\n r4 = r12;\n goto L_0x00a3;\n L_0x0118:\n r13 = r12;\n r6 = r18;\n goto L_0x000f;\n L_0x011d:\n r0 = (long) r14;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r16 = r16 + r6;\n r19 = 0;\n r20 = 20;\n r15 = r26;\n r18 = r8;\n r21 = r27;\n r15.j6(r16, r18, r19, r20, r21);\t Catch:{ DataFormatException -> 0x004d }\n r5 = ans.j6(r8);\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r18 = r0.j6(r5);\t Catch:{ DataFormatException -> 0x004d }\n r12 = new aro$a;\t Catch:{ DataFormatException -> 0x004d }\n r0 = (int) r10;\t Catch:{ DataFormatException -> 0x004d }\n r16 = r0;\n r17 = r14 + 20;\n r14 = r6;\n r12.<init>(r13, r14, r16, r17, r18);\t Catch:{ DataFormatException -> 0x004d }\n r5 = r12.FH;\t Catch:{ DataFormatException -> 0x004d }\n r14 = (long) r5;\t Catch:{ DataFormatException -> 0x004d }\n r5 = (r10 > r14 ? 1 : (r10 == r14 ? 0 : -1));\n if (r5 == 0) goto L_0x0153;\n L_0x014b:\n r10 = r22;\n r9 = r23;\n r8 = r4;\n r4 = r12;\n goto L_0x00a3;\n L_0x0153:\n r5 = r27.Hw();\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r18;\n r5 = r5.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n if (r5 == 0) goto L_0x016a;\n L_0x0161:\n r9 = r5.DW;\t Catch:{ DataFormatException -> 0x004d }\n r4 = r5.j6;\t Catch:{ DataFormatException -> 0x004d }\n r10 = 1;\n r8 = r4;\n r4 = r12;\n goto L_0x00a3;\n L_0x016a:\n r13 = r12;\n r6 = r18;\n goto L_0x000f;\n L_0x016f:\n r10 = r4;\n r11 = r8;\n r28 = r6;\n r8 = r5;\n L_0x0174:\n if (r10 == 0) goto L_0x0196;\n L_0x0176:\n r4 = 0;\n L_0x0177:\n r6 = r11.DW;\t Catch:{ DataFormatException -> 0x01db }\n r5 = r11.Hw;\t Catch:{ DataFormatException -> 0x004d }\n r12 = (long) r5;\t Catch:{ DataFormatException -> 0x004d }\n r12 = r12 + r6;\n r5 = r11.FH;\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r27;\n r10 = r0.j6(r12, r5, r1);\t Catch:{ DataFormatException -> 0x004d }\n if (r10 != 0) goto L_0x01a7;\n L_0x0189:\n r4 = 0;\n r4 = (byte[]) r4;\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r27;\n r8 = r11.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x0196:\n r4 = r11.j6;\t Catch:{ DataFormatException -> 0x01db }\n if (r4 != 0) goto L_0x01a5;\n L_0x019a:\n r4 = r27.Hw();\t Catch:{ DataFormatException -> 0x01db }\n r6 = r11.v5;\t Catch:{ DataFormatException -> 0x01db }\n r5 = r26;\n r4.j6(r5, r6, r8, r9);\t Catch:{ DataFormatException -> 0x01db }\n L_0x01a5:\n r4 = r10;\n goto L_0x0177;\n L_0x01a7:\n r12 = asj.j6(r10);\t Catch:{ DataFormatException -> 0x004d }\n r14 = 2147483647; // 0x7fffffff float:NaN double:1.060997895E-314;\n r5 = (r14 > r12 ? 1 : (r14 == r12 ? 0 : -1));\n if (r5 > 0) goto L_0x01bc;\n L_0x01b2:\n r0 = r26;\n r1 = r27;\n r8 = r11.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x01bc:\n r5 = (int) r12;\n r5 = new byte[r5];\t Catch:{ OutOfMemoryError -> 0x01cd }\n asj.j6(r8, r10, r5);\t Catch:{ DataFormatException -> 0x004d }\n r8 = r11.j6;\t Catch:{ DataFormatException -> 0x004d }\n if (r8 != 0) goto L_0x016f;\n L_0x01c6:\n r8 = new anx$a;\t Catch:{ DataFormatException -> 0x004d }\n r8.<init>(r9, r5);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x01cd:\n r4 = move-exception;\n r4 = 0;\n r4 = (byte[]) r4;\t Catch:{ DataFormatException -> 0x004d }\n r0 = r26;\n r1 = r27;\n r8 = r11.j6(r0, r1);\t Catch:{ DataFormatException -> 0x004d }\n goto L_0x00ad;\n L_0x01db:\n r4 = move-exception;\n r6 = r28;\n goto L_0x004e;\n L_0x01e0:\n r11 = r4;\n r28 = r6;\n goto L_0x0174;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: aro.j6(asg, long):anx\");\n }", "public abstract void mo9813b(long j);", "void mo41086b();", "void mo28891b(int i, long j) throws zzlm;", "void mo1638a(long j, long j2, List list, ayp ayp);", "private void m50957b(long j) {\n if (!this.f36886a.isEmpty()) {\n C8785fs.m51740a(new C8671cf(this), j);\n }\n }", "private void kk12() {\n\n\t}", "public abstract void mo4382c(int i, long j);", "public abstract void mo9803a(int i, C3635j jVar);", "void mo98971a(C29296g gVar, int i);", "public abstract void mo9812b(int i, C3635j jVar);", "public abstract void mo4369a(long j);", "void mo119582b();", "public abstract AbstractC5665f mo39571a(long j);", "void mo72113b();", "public abstract void mo9811b(int i, long j);", "public final void mo7667gm(long j) {\n }", "public abstract AbstractC5663d mo39570a(long j, int i);", "public String func_176882_c() {\n/* */ return this.field_176891_j;\n/* */ }", "public void mo21782G() {\n }", "public interface C38422j {\n /* renamed from: nm */\n void mo6247nm(int i);\n}", "public int j() {\n \treturn j; \n }", "public void mo9223a(long j, int i, int i2) {\n }", "void mo21073d();", "void mo57278c();", "static void jhat() {\n\n }", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "@Override\n\tpublic void jugar() {\n\t\t\n\t}", "void mo56163g();", "void mo80454a(File file, long j);", "public abstract int mo9745j();", "void mo67923b();", "void mo80455b();", "public int g()\r\n/* 173: */ {\r\n/* 174:198 */ return 0;\r\n/* 175: */ }", "public void mo5335a(int i, C0268jw jwVar) {\n }", "public void golpearJugador(Jugador j) {\n\t\t\n\t}", "C2841w mo7234g();", "static void jmap() {\n\n }", "void mo88523b();", "static void jcmd() {\n\n }", "void mo1761g(int i);", "@Nullable\r\n/* */ public ji Z_() {\r\n/* 257 */ return new ji(this.d_, 3, aa_());\r\n/* */ }", "C3579d mo19716j(long j) throws IOException;", "void jugar(Jugada jugada);", "@Override\n\tpublic void jugar() {}", "protected void a(bug parambug)\r\n/* 35: */ {\r\n/* 36:36 */ this.j.a((bxf)null);\r\n/* 37: */ }", "public void mo21779D() {\n }", "public static int m22579g(long j) {\n return 8;\n }", "void mo13371a(int i, long j);", "public interface C33322h {\n /* renamed from: J */\n void mo34547J(float f, float f2);\n}", "protected void mo1603c(long j) {\n this.f7046g = j;\n }", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "void mo41083a();", "private void m50953a(long j) {\n C8667b peek = this.f36886a.peek();\n if (peek != null && peek.mo54372d()) {\n m50957b(j);\n }\n }", "void mo28307a(zzgd zzgd);", "public interface C11316t5 extends C11259p5, Cloneable {\n /* renamed from: j0 */\n C11316t5 mo29022j0();\n}", "void mo25957a(long j, long j2);", "void mo60893b();", "private C0382g m1366j(C0380e eVar) {\n return (C0382g) eVar.mo2738c();\n }", "static /* synthetic */ void m34120F(int i, long j) {\n AppMethodBeat.m2504i(114776);\n C22440b c22440b;\n if (i == 11) {\n c22440b = new C22440b();\n c22440b.startTime = System.currentTimeMillis();\n sJR.put(Long.valueOf(j), c22440b);\n AppMethodBeat.m2505o(114776);\n return;\n }\n if (i == 12) {\n if (!sJR.containsKey(Long.valueOf(j))) {\n new C22440b().startTime = System.currentTimeMillis();\n AppMethodBeat.m2505o(114776);\n return;\n }\n } else if (i == 13) {\n c22440b = (C22440b) sJR.get(Long.valueOf(j));\n if (c22440b != null) {\n c22440b.endTime = System.currentTimeMillis();\n sJT.add(c22440b);\n sJR.remove(Long.valueOf(j));\n }\n }\n AppMethodBeat.m2505o(114776);\n }", "void mo3193f();", "public abstract boolean mo43853a(long j);", "public void mo5334a(int i, int i2, C0283kk kkVar, C0268jw jwVar) {\n }", "C3197iu mo30281b(long j);", "void mo28306a();", "public void f() {\n this.f25459e.J();\n }", "void mo21074e();", "private int e(amj paramamj)\r\n/* 202: */ {\r\n/* 203:221 */ alq localalq = paramamj.b();\r\n/* 204:222 */ int i = paramamj.b;\r\n/* 205: */ \r\n/* 206:224 */ int j = d(paramamj);\r\n/* 207:225 */ if (j < 0) {\r\n/* 208:226 */ j = j();\r\n/* 209: */ }\r\n/* 210:228 */ if (j < 0) {\r\n/* 211:229 */ return i;\r\n/* 212: */ }\r\n/* 213:231 */ if (this.a[j] == null)\r\n/* 214: */ {\r\n/* 215:232 */ this.a[j] = new amj(localalq, 0, paramamj.i());\r\n/* 216:233 */ if (paramamj.n()) {\r\n/* 217:234 */ this.a[j].d((fn)paramamj.o().b());\r\n/* 218: */ }\r\n/* 219: */ }\r\n/* 220:238 */ int k = i;\r\n/* 221:239 */ if (k > this.a[j].c() - this.a[j].b) {\r\n/* 222:240 */ k = this.a[j].c() - this.a[j].b;\r\n/* 223: */ }\r\n/* 224:242 */ if (k > p_() - this.a[j].b) {\r\n/* 225:243 */ k = p_() - this.a[j].b;\r\n/* 226: */ }\r\n/* 227:246 */ if (k == 0) {\r\n/* 228:247 */ return i;\r\n/* 229: */ }\r\n/* 230:250 */ i -= k;\r\n/* 231:251 */ this.a[j].b += k;\r\n/* 232:252 */ this.a[j].c = 5;\r\n/* 233: */ \r\n/* 234:254 */ return i;\r\n/* 235: */ }", "private void m10265b(long j) throws cf {\r\n int i = 0;\r\n while ((-128 & j) != 0) {\r\n int i2 = i + 1;\r\n this.f6476b[i] = (byte) ((int) ((127 & j) | 128));\r\n j >>>= 7;\r\n i = i2;\r\n }\r\n int i3 = i + 1;\r\n this.f6476b[i] = (byte) ((int) j);\r\n this.g.mo1990b(this.f6476b, 0, i3);\r\n }", "public void mo21877s() {\n }", "C4135d0 mo1484a(int i, long j);", "public void mo21787L() {\n }", "void mo28888a(int i, long j, long j2) throws zzlm;", "public int g()\r\n/* 601: */ {\r\n/* 602:645 */ return 0;\r\n/* 603: */ }", "public void mo21825b() {\n }", "public void mo97908d() {\n }", "public abstract void mo20156a(long j);", "public abstract void mo9801a(int i, long j);", "@VisibleForTesting\n public final long g(long j) {\n long j2 = j - this.f10062b;\n this.f10062b = j;\n return j2;\n }", "public abstract C0270jy mo5354b();", "void mo28194a();" ]
[ "0.7311624", "0.706263", "0.6640178", "0.6600015", "0.6516509", "0.6496756", "0.6477138", "0.6465923", "0.6462825", "0.63734293", "0.6337201", "0.6314744", "0.6305913", "0.62804645", "0.6271484", "0.62562865", "0.62322694", "0.6232011", "0.62164783", "0.62164783", "0.6200328", "0.61989844", "0.6194939", "0.6194225", "0.61941504", "0.61905384", "0.61832523", "0.6171091", "0.6160147", "0.61451596", "0.6140553", "0.6127965", "0.61235994", "0.6115606", "0.6114288", "0.61112607", "0.6110529", "0.6099228", "0.60936123", "0.6088152", "0.6071781", "0.6071264", "0.6065391", "0.6064694", "0.60455036", "0.60436136", "0.6040459", "0.60395384", "0.6029316", "0.6029012", "0.6026071", "0.59908444", "0.59889275", "0.5980726", "0.5973856", "0.5973015", "0.59691894", "0.5961208", "0.5960678", "0.5953692", "0.5953059", "0.5952559", "0.59514314", "0.59479266", "0.5946476", "0.5940778", "0.59398466", "0.5933995", "0.59311587", "0.5926773", "0.5924683", "0.5921412", "0.5919345", "0.5918609", "0.5915498", "0.5911309", "0.59084934", "0.59073323", "0.59022015", "0.5901566", "0.5890369", "0.58901685", "0.5890082", "0.5888403", "0.58879876", "0.5886639", "0.5884204", "0.5883682", "0.58755684", "0.5874376", "0.58729506", "0.5869852", "0.58690155", "0.58616656", "0.58614403", "0.5858542", "0.5856789", "0.5853912", "0.5852347", "0.5849872", "0.58484524" ]
0.0
-1
$FF: renamed from: d (int, int, int, int, int, int) java.util.List
public List method_2245(int param1, int param2, int param3, int param4, int param5, int param6) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public abstract void mo56923b(List<C4122e> list);", "void mo100444b(List<C40429b> list);", "public abstract void mo56920a(List<C4122e> list);", "int mo1635a(long j, List list);", "void mo1638a(long j, long j2, List list, ayp ayp);", "public void m(List<?> list) {\n\t}", "void mo54419a(List<String> list);", "void mo13370a(int i, int i2, List<C15929a> list) throws IOException;", "ListType createListType();", "void mo13375a(boolean z, int i, int i2, List<C15929a> list);", "void addAll(intList list) throws IllegalAccessException;", "public abstract List<T> mo2625k();", "abstract void makeList();", "void mo9148a(int i, ArrayList<C0889x> arrayList);", "public void bar(java.util.List<java.lang.Integer> foo) { return; }", "public final void accept(List<? extends com.iqoption.fragment.c.a.a.j> list) {\n a aVar = this.dhx.dhv.dhu;\n kotlin.jvm.internal.i.e(list, \"list\");\n aVar.aU(list);\n }", "Object getTolist();", "private void m1088a(List<Integer> list) {\n this.f688c = list;\n }", "Listof<X> toList();", "List<C1111j> mo5873b();", "private Lists() { }", "public abstract ArrayList<Integer> getIdList();", "private static <T> List<T> list(T... elements) {\n return ImmutableList.copyOf(elements);\n }", "java.util.List<java.lang.Integer> getItemsList();", "public MemberList(List members)\n/* 10: */ {\n/* 11:10 */ this.members = members;\n/* 12: */ }", "void addAll(intList list, int index) throws IllegalAccessException;", "void mo100443a(List<String> list);", "public interface DList {\n}", "public void genLists() {\n\t}", "public XSListSimpleType asList() {\n // This method could not be decompiled.\n // \n // Original Bytecode:\n // \n // 0: idiv \n // 1: laload \n // LocalVariableTable:\n // Start Length Slot Name Signature\n // ----- ------ ---- ---- ------------------------------------------\n // 0 2 0 this Lcom/sun/xml/xsom/impl/ListSimpleTypeImpl;\n // \n // The error that occurred was:\n // \n // java.lang.ArrayIndexOutOfBoundsException\n // \n throw new IllegalStateException(\"An error occurred while decompiling this method.\");\n }", "private static <T> List<T> m971u(List<T> list) {\n return list == null ? Collections.emptyList() : list;\n }", "protected List getList() {\n/* 88 */ return (List)getCollection();\n/* */ }", "public List<New> list();", "List<?> getList();", "List<C1111j> mo5868a();", "private Int64List(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "List<C1111j> mo5869a(int i);", "private static <T> List<T> m450e(List<T> list) {\n return list == null ? Collections.emptyList() : list;\n }", "void mo7380a(C1320b bVar, List<String> list) throws RemoteException;", "public ListTimer(List<Integer> list){\n\t\tsuper();\n\t\tthis.list = list;\n\t}", "int getListData(int list) {\n\t\treturn m_lists.getField(list, 5);\n\t}", "public DList2 list(){\r\n return this.list;\r\n }", "@NotNull\n private static List<P> list(P... ps) {\n List<P> result = new ArrayList<>();\n Collections.addAll(result, ps);\n return result;\n }", "public interface ListConverterList<From,To> extends Converter<List<From>,List<To>> {\r\n}", "int mo13159a(List<Log> list);", "declaration_list2 getDeclaration_list2();", "@Override\n\tpublic void visit(ValueListExpression arg0) {\n\t\t\n\t}", "public void setListProperty(List<Integer> t) {\n\n\t\t}", "public static <C> LIST<C> LIST4(C a, C b, C c, C d) {\n LIST<C> L = new LIST<C>();\n L.list.addFirst( d );\n L.list.addFirst( c );\n L.list.addFirst( b );\n L.list.addFirst( a );\n return L;\n }", "public int[] getIntList();", "java.util.List<java.lang.Integer> getItemList();", "public final List<l> apply(List<j> list) {\n kotlin.jvm.internal.h.e(list, \"it\");\n boolean a = this.dlr.a(this.dls, list);\n Iterable<j> iterable = list;\n Collection arrayList = new ArrayList(n.e(iterable, 10));\n for (j jVar : iterable) {\n kotlin.jvm.internal.h.d(jVar, \"it\");\n arrayList.add(new l(jVar, a ^ 1));\n }\n return (List) arrayList;\n }", "public ListTimer(List<Integer> list, long elemGenSeed){\n\t\tsuper(elemGenSeed);\n\t\tthis.list = list;\n\n\t}", "List<String> d();", "@Test public void asListSimple() {\n @SuppressWarnings(\"null\") final @NotNull List<Integer> is = as.list(new int @NotNull [] { 12, 13, 14 });\n azzert.that(is.get(0), is(fluent.ly.box.it(12)));\n azzert.that(is.get(1), is(fluent.ly.box.it(13)));\n azzert.that(is.get(2), is(fluent.ly.box.it(14)));\n azzert.that(is.size(), is(3));\n }", "protected abstract List<E> getList();", "private void initList() {\n\n }", "public void setList(List<Integer> list) {\n this.list = list;\n }", "List<C1700ar> mo7233f();", "void mo1929a(int i, int i2, List<DkCloudRedeemFund> list);", "public static void addList() {\n\t}", "public interface C0601aq {\n /* renamed from: a */\n void mo9148a(int i, ArrayList<C0889x> arrayList);\n}", "abstract protected Object newList( int capacity );", "public abstract java.util.Map<java.lang.Double, java.util.List<java.lang.Integer>> pnlListMap();", "public interface List<E> {\n\n /**\n * Return number of elements in the list\n * @return Number of elements\n */\n int size();\n\n /**\n * Returns whether the list is empty\n * @return True if the list is empty, false otherwise\n */\n boolean isEmpty();\n\n /**\n * Returns the element at index i\n * @param i Index\n * @return Element at i\n * @exception IndexOutOfBoundsException If i is not valid, exception\n */\n E get(int i) throws IndexOutOfBoundsException;\n\n /**\n * Replaces the element at index i with e, and returns the replaced element\n * @param i Index\n * @param e New element\n * @return Element replaced by e\n * @exception IndexOutOfBoundsException If i is not valid, exception\n */\n E set(int i, E e) throws IndexOutOfBoundsException;\n\n /**\n * Inserts element e to be at index i, shifting all subsequent elements later\n * @param i Index\n * @param e New element\n * @exception IndexOutOfBoundsException If i is not valid, exception\n */\n void add(int i, E e) throws IndexOutOfBoundsException;\n\n /**\n * Removes and returns the element at index i, shifting subsequent elements\n * earlier\n * @param i Index\n * @return Element previously at i\n * @exception IndexOutOfBoundsException If i is not valid, exception\n */\n E remove(int i) throws IndexOutOfBoundsException;\n\n /**\n * Empty the list\n */\n public void clear();\n\n /**\n * Construct a clone (copy) of the object.\n * @return New list object with the same structure. This copy should be\n * shallow, i.e., the individual elements are not cloned.\n */\n public List<E> clone();\n}", "List<E> list();", "public abstract List<C41717j> mo70725h(String str);", "public List<String> c(String paramString, int paramInt)\r\n/* 608: */ {\r\n/* 609:605 */ return Arrays.asList(d(paramString, paramInt).split(\"\\n\"));\r\n/* 610: */ }", "java.util.List<com.mwr.jdiesel.api.Protobuf.Message.Argument> \n getElementList();", "static /* synthetic */ List m17132a(List list) throws Exception {\n ArrayList arrayList = new ArrayList(list);\n Collections.sort(arrayList, f15631B0);\n return arrayList;\n }", "public final void accept(List<l> list) {\n com.iqoption.core.data.b.c a = this.dlr.dlm;\n kotlin.jvm.internal.h.d(list, \"it\");\n a.setValue(list);\n }", "private ImmutableIntList(int... ints) {\n this.ints = ints;\n }", "@Override\n\tpublic void acheter(List<Object> la) {\n\t\t\n\t}", "private static interface T {@Symbolic Term.List t();}", "public void AddList( TColStd_HSequenceOfTransient list) {\n OCCwrapJavaJNI.Interface_EntityIterator_AddList(swigCPtr, this, TColStd_HSequenceOfTransient.getCPtr(list) , list);\n }", "public static void clientFunc(){\n List list = new ArrayList(); //rawtype list\n list.add(10);\n list.add(\"jenkins\");\n list.add(new Object());\n\n //unsafe classcast exception at runtime\n //rawtypes are unsafe\n List<String> stringList = list;\n\n ListIterator listIterator = list.listIterator();\n while(listIterator.hasNext()){\n System.out.println(listIterator.next());\n }\n }", "private static List<C31644f<?, R>> m102869a() {\n return new ArrayList<>();\n }", "private List(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "private static Type getListType() {\n return getListTypeToken().getType();\n }", "List<C45111a> mo107675a(Integer num, Integer num2);", "public abstract List<T> getList();", "void mo29842a(IObjectWrapper iObjectWrapper, zzatk zzatk, List<String> list) throws RemoteException;", "@DSComment(\"From safe class list\")\n @DSSafe(DSCat.SAFE_LIST)\n @DSGenerator(tool_name = \"Doppelganger\", tool_version = \"2.0\", generated_on = \"2013-12-30 12:56:09.367 -0500\", hash_original_method = \"4A1605B03FE1E22048A20B9E05E481A5\", hash_generated_method = \"4396D2BAEFB73347858E563F022F81BC\")\n \n@Override\n public String toString() {\n return getClass().getName() + '(' + getName() + ')';\n }", "public interface List<E> {\n /** Returns the number of elements in this list */\n int size();\n /** Returns whether the list is empty */\n boolean isEmpty();\n\n E get(int i) throws IndexOutOfBoundsException;\n\n E set(int i, E e) throws IndexOutOfBoundsException;\n\n void add(int i, E e) throws IndexOutOfBoundsException;\n\n E remove(int i) throws IndexOutOfBoundsException;\n}", "abstract List<T> getReuslt();", "@Override\r\n\tpublic Object visitListExpression(ListExpression listExpression, Object arg)\r\n\t\t\tthrows Exception {\r\n\t\tif (listExpression.expressionList.isEmpty()) {\t\r\n\t\t\tlistExpression.setType(emptyList);\r\n\t\t\treturn emptyList;\r\n\t\t}\t\t\r\n\t\tString oldListType = (String) listExpression.expressionList.get(0).visit(this, arg);\r\n\t\tfor(Expression expr : listExpression.expressionList) {\r\n\t\t\tString listType = (String) expr.visit(this, arg);\r\n\t\t\tcheck(oldListType.equals(listType),\t\"uncompatible list type\", listExpression);\r\n\t\t\toldListType = listType;\t\t\t\r\n\t\t}\r\n\t\tString listType = \"Ljava/util/ArrayList<\" + oldListType + \">;\";\r\n\t\tlistExpression.setType(listType);\r\n\t\treturn listType;\r\n\t}", "List<String> mo5876c();", "ListValue createListValue();", "static void q2(){\n\t\tArrayList<Integer>myList=new ArrayList<>();\n\t\t\n\t}", "private static <T> TypeToken<List<T>> getListTypeToken() {\n return new TypeToken<List<T>>() {\n };\n }", "java.util.List<java.lang.Integer> getListSnIdList();", "a(List list) {\n super(1);\n this.$sortedList = list;\n }", "public abstract void mo9247b(String str, long j, List<String> list);", "List <JAVATYPE> convertList(List<JAVATYPE> oldList, final METATYPE meta);", "private ConstList(List<T> list) {\n this.list = list;\n }", "private List<View> m9533a(List<View> list, List<View> list2) {\n LinkedList linkedList = new LinkedList();\n if (list != null && !list.isEmpty()) {\n int size = list.size();\n for (int i = 0; i < size; i++) {\n linkedList.add(list.get(i));\n }\n }\n if (list2 != null && !list2.isEmpty()) {\n int size2 = list2.size();\n for (int i2 = 0; i2 < size2; i2++) {\n linkedList.add(list2.get(i2));\n }\n }\n return linkedList;\n }", "public interface ISimpleList<Type> extends Iterable<Type> {\n /**\n * Add a value to the end of this list.\n * \n * @param t is the value added to this list\n */\n public void add(Type t);\n\n /**\n * Add a value at a specified index in the list, shifting other values to\n * make room.\n * \n * @param index is the index at which new value added\n * @param t the new value added\n * @throws IndexOutOfBoundsException\n * if index is greater than size of list or less than zero\n */\n public void add(int index, Type t);\n\n /**\n * Returns an iterator over this list's values, the iterator supports\n * remove.\n * \n * @return iterator (supporting remove))\n */\n public Iterator<Type> iterator();\n\n /**\n * Remove and return the value at the specified index, shifting other values\n * \n * @param index of value to remove\n * @return the removed value\n * @throws IndexOutOfBoundsException\n * if index < 0 or >= size()\n */\n public Type remove(int index);\n\n /**\n * Remove first occurrence of a value, and return true iff removal succeeds.\n * \n * @param t is value removed\n * @return true if a value is removed, false otherwise\n */\n public boolean remove(Type t);\n\n /**\n * Return the value at the specified index.\n * \n * @param index of value to return\n * @return value at specified index\n * @throws IndexOutOfBoundsException\n * if index < 0 or >= size()\n */\n public Type get(int index);\n\n /**\n * Return index of first occurrence of a value, or -1 if not found.\n * \n * @param t is valuel searched for\n * @return index of first occurrence of t, or -1 if t not found\n */\n public int indexOf(Type t);\n\n /**\n * Returns number of elements in this list.\n * \n * @return number of elements in list\n */\n public int size();\n}", "public List getList();", "public MultiList(int listType){\n this.listType = listType;\n }", "public static <T> List<T> createList (T... args) {\n\tif (args == null) { return new ArrayList<T>(); };\n\treturn new ArrayList<T>(Arrays.asList(args));\n }" ]
[ "0.72708315", "0.7264592", "0.7097515", "0.64868474", "0.64790106", "0.64294434", "0.6429071", "0.6408953", "0.63786733", "0.6341949", "0.63341194", "0.6268458", "0.6250253", "0.6238906", "0.6238142", "0.62021726", "0.6186605", "0.6182769", "0.6174729", "0.61604714", "0.61575574", "0.61501825", "0.6129168", "0.61223125", "0.6116405", "0.6114399", "0.6100569", "0.609417", "0.60889995", "0.6088381", "0.6078878", "0.6049741", "0.60321504", "0.6018277", "0.60133934", "0.60057074", "0.5988624", "0.5987889", "0.5985429", "0.59772605", "0.59624875", "0.5959347", "0.5954908", "0.5944326", "0.5942789", "0.5935732", "0.5932297", "0.59272146", "0.59265125", "0.592649", "0.5922962", "0.59177554", "0.5905949", "0.5894694", "0.5890783", "0.58885396", "0.5885129", "0.5883779", "0.5866292", "0.5859142", "0.584345", "0.5843358", "0.58415127", "0.58230686", "0.58199763", "0.58110756", "0.580315", "0.5794838", "0.5794282", "0.57896006", "0.5780541", "0.5778586", "0.57721734", "0.57693666", "0.5764885", "0.5761893", "0.5760491", "0.5759463", "0.5758552", "0.57582265", "0.57564694", "0.575121", "0.5748742", "0.5744896", "0.57320404", "0.57269526", "0.57195824", "0.57161826", "0.57085675", "0.5703705", "0.5703025", "0.57018566", "0.5701018", "0.56959933", "0.5692657", "0.5687924", "0.5684311", "0.5674947", "0.56721747", "0.56702626" ]
0.603356
32
$FF: renamed from: a (yz, int, int, int) boolean
public boolean method_2190(class_792 var1, int var2, int var3, int var4) { String[] var5 = class_752.method_4253(); boolean var10000; label32: { try { var10000 = this.field_1850.method_2394(this, var2, var3, var4, var1); if(var5 == null) { return var10000; } if(!var10000) { break label32; } } catch (IllegalStateException var6) { throw method_2260(var6); } var10000 = false; return var10000; } var10000 = true; return var10000; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo54420a(boolean z, boolean z2);", "void mo64153a(boolean z);", "void mo6661a(boolean z);", "void mo99838a(boolean z);", "void mo21069a(boolean z);", "void mo3305a(boolean z);", "void mo1488a(boolean z);", "void mo98208a(boolean z);", "void mo54415a(int i, boolean z);", "void mo12636a(boolean z);", "abstract void mo956a(boolean z);", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "void mo13374a(boolean z, int i, int i2);", "void mo1492b(boolean z);", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "void mo13377a(boolean z, C15943j c15943j);", "void mo28742b(boolean z, int i);", "public abstract void mo32006dL(boolean z);", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "void mo9701a(boolean z);", "public abstract void mo9806a(int i, boolean z);", "void mo28309a(boolean z, int i);", "void mo22049es(boolean z);", "void mo21071b(boolean z);", "void mo197b(boolean z);", "public boolean a(World paramaqu, BlockPosition paramdt, Block parambec, boolean paramBoolean)\r\n/* 67: */ {\r\n/* 68: 83 */ return true;\r\n/* 69: */ }", "public abstract void mo4368a(int i, boolean z);", "public abstract boolean a();", "void boolean1(boolean a);", "@Nullable\n /* renamed from: a */\n public abstract C4891ao mo18474a(Object obj, boolean z);", "public final void mo5689a(boolean z) {\n }", "public void mo97903a(boolean z) {\n }", "protected abstract boolean a(axz paramaxz, long paramLong, int paramInt1, int paramInt2, double paramDouble1, double paramDouble2, double paramDouble3, double paramDouble4, double paramDouble5, BitSet paramBitSet);", "boolean mo2803a(boolean z);", "public abstract void mo9254f(boolean z);", "protected void a(int paramInt1, int paramInt2, boolean paramBoolean, yz paramyz) {}", "public final void mo12411a(boolean z) {\n }", "public abstract boolean mo43853a(long j);", "public abstract boolean mo66253b();", "public abstract void mo32007dM(boolean z);", "public void am(boolean z) {\n }", "public interface AbstractC10485b {\n /* renamed from: a */\n void mo64153a(boolean z);\n }", "public abstract boolean a(e parame, b paramb, int paramInt1, int paramInt2);", "void mo13369a(int i, int i2, int i3, boolean z);", "public abstract boolean mo9234ar();", "public void mo97905b(boolean z) {\n }", "boolean booleanOf();", "public void b(boolean paramBoolean)\r\n/* 603: */ {\r\n/* 604:601 */ this.l = paramBoolean;\r\n/* 605: */ }", "public final boolean func_boolean_a(int var1, int var2) {\n if (this.func_boolean_b(var1, var2)) {\n return true;\n } else if (var2 != 53 && var1 != 8) {\n if (var2 == -8) {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)0);\n return true;\n } else {\n return true;\n }\n } else {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)1);\n return true;\n }\n }", "void mo26249mh(boolean z);", "public void ak(boolean z) {\n }", "public boolean b(int paramInt, amj paramamj)\r\n/* 578: */ {\r\n/* 579:621 */ return true;\r\n/* 580: */ }", "public boolean a(World paramaqu, BlockPosition paramdt, EnumDirection paramej)\r\n/* 42: */ {\r\n/* 43: 62 */ return false;\r\n/* 44: */ }", "public abstract void mo32005dK(boolean z);", "public interface C0736a {\n void mo559a(C0724g c0724g, boolean z);\n\n boolean mo560a(C0724g c0724g);\n }", "@SuppressWarnings(\"UnusedDeclaration\")\npublic interface LObjBoolPair<T> extends LTuple<Object> \n {\n\n int SIZE = 2;\n\n\n T first();\n\n default T value() {\n return first();\n }\n\n boolean second();\n\n\n\n @Override default Object get(int index) {\n switch(index) {\n case 1: return first();\n case 2: return second();\n default: throw new NoSuchElementException();\n }\n }\n\n\n /** Tuple size */\n @Override default int tupleSize() {\n return SIZE;\n }\n\n \n\n /** Static hashCode() implementation method that takes same arguments as fields of the LObjBoolPair and calculates hash from it. */\n static <T> int argHashCode(T a1,boolean a2) {\n final int prime = 31;\n int result = 1;\n result = prime * result + ((a1 == null) ? 0 : a1.hashCode());\n result = prime * result + Boolean.hashCode(a2);\n return result;\n }\n\n /** Static equals() implementation that takes same arguments (doubled) as fields of the LObjBoolPair and checks if all values are equal. */\n static <T> boolean argEquals(T a1,boolean a2, T b1,boolean b2) {\n return\n Null.equals(a1, b1) && //\n a2==b2; //\n }\n\n /**\n * Static equals() implementation that takes two tuples and checks if they are equal.\n * Tuples are considered equal if are implementing LObjBoolPair interface (among others) and their LObjBoolPair values are equal regardless of the implementing class\n * and how many more values there are.\n */\n static boolean argEquals(LObjBoolPair the, Object that) {\n return Null.equals(the, that, (one, two) -> {\n // Intentionally all implementations of LObjBoolPair are allowed.\n if (!(two instanceof LObjBoolPair)) {\n return false;\n }\n\n LObjBoolPair other = (LObjBoolPair) two;\n\n return argEquals(one.first(), one.second(), other.first(), other.second());\n });\n }\n\n /**\n * Static equals() implementation that takes two tuples and checks if they are equal.\n */\n public static boolean tupleEquals(LObjBoolPair the, Object that) {\n return Null.equals(the, that, (one, two) -> {\n // Intentionally all implementations of LObjBoolPair are allowed.\n if (!(two instanceof LObjBoolPair)) {\n return false;\n }\n\n LObjBoolPair other = (LObjBoolPair) two;\n\n return one.tupleSize() == other.tupleSize() &&\n argEquals(one.first(), one.second(), other.first(), other.second());\n });\n }\n\n\n\n \n @Override default Iterator<Object> iterator() {\n return new Iterator<Object>() {\n\n private int index;\n\n @Override public boolean hasNext() {\n return index<SIZE;\n }\n\n @Override public Object next() {\n index++;\n return get(index);\n }\n };\n }\n\n interface ComparableObjBoolPair<T extends Comparable<? super T>> extends LObjBoolPair<T>, Comparable<LObjBoolPair<T>> {\n @Override\n default int compareTo(LObjBoolPair<T> that) {\n return Null.compare(this, that, (one, two) -> {\n int retval = 0;\n\n return\n (retval = Null.compare(one.first(), two.first())) != 0 ? retval : //\n (retval = Boolean.compare(one.second(), two.second())) != 0 ? retval : 0; //\n });\n }\n\n }\n \n\n abstract class AbstractObjBoolPair<T> implements LObjBoolPair<T> {\n\n @Override\n public boolean equals(Object that) {\n return LObjBoolPair.tupleEquals(this, that);\n }\n\n @Override\n public int hashCode() {\n return LObjBoolPair.argHashCode(first(),second());\n }\n\n @Override\n public String toString() {\n StringBuilder sb = new StringBuilder();\n sb.append('(');\n sb.append(first());\n sb.append(',');\n sb.append(second());\n sb.append(')');\n return sb.toString();\n }\n\n }\n\n\n\n\n\n /**\n * Mutable tuple.\n */\n\n interface Mut<T,SELF extends Mut<T,SELF>> extends LObjBoolPair<T> {\n\n\n\n SELF first(T first) ; \n SELF second(boolean second) ; \n\n default SELF setFirst(T first) {\n this.first(first);\n return (SELF) this;\n }\n\n\n /** Sets value if predicate(current) is true */\n default SELF setFirstIf(T first, LPredicate<T> predicate) {\n if (predicate.test(this.first())) {\n return this.first(first);\n }\n return (SELF) this;\n }\n\n /** Sets new value if predicate predicate(newValue, current) is true. */\n default SELF setFirstIf(T first, LBiPredicate<T,T> predicate) {\n if (predicate.test(first, this.first())) {\n return this.first(first);\n }\n return (SELF) this;\n }\n\n /** Sets new value if predicate predicate(current, newValue) is true. */\n default SELF setFirstIf(LBiPredicate<T,T> predicate, T first) {\n if (predicate.test(this.first(), first)) {\n return this.first(first);\n }\n return (SELF) this;\n }\n \n\n\n default SELF setSecond(boolean second) {\n this.second(second);\n return (SELF) this;\n }\n\n\n /** Sets value if predicate(current) is true */\n default SELF setSecondIf(boolean second, LLogicalOperator predicate) {\n if (predicate.apply(this.second())) {\n return this.second(second);\n }\n return (SELF) this;\n }\n\n /** Sets new value if predicate predicate(newValue, current) is true. */\n default SELF setSecondIf(boolean second, LLogicalBinaryOperator predicate) {\n if (predicate.apply(second, this.second())) {\n return this.second(second);\n }\n return (SELF) this;\n }\n\n /** Sets new value if predicate predicate(current, newValue) is true. */\n default SELF setSecondIf(LLogicalBinaryOperator predicate, boolean second) {\n if (predicate.apply(this.second(), second)) {\n return this.second(second);\n }\n return (SELF) this;\n }\n \n\n\n default SELF reset() {\n this.first(null);\n this.second(false);\n return (SELF) this;\n }\n }\n\n\n\n\n\n\n public static <T> MutObjBoolPair<T> of() { \n return of( null , false );\n }\n \n\n public static <T> MutObjBoolPair<T> of(T a1,boolean a2){\n return new MutObjBoolPair(a1,a2);\n }\n\n public static <T> MutObjBoolPair<T> copyOf(LObjBoolPair<T> tuple) {\n return of(tuple.first(), tuple.second());\n }\n\n\n /**\n * Mutable, non-comparable tuple.\n */\n\n class MutObjBoolPair<T> extends AbstractObjBoolPair<T> implements Mut<T,MutObjBoolPair<T>> {\n\n private T first;\n private boolean second;\n\n public MutObjBoolPair(T a1,boolean a2){\n this.first = a1;\n this.second = a2;\n }\n\n\n public @Override T first() {\n return first;\n }\n\n public @Override MutObjBoolPair<T> first(T first) {\n this.first = first;\n return this;\n }\n \n public @Override boolean second() {\n return second;\n }\n\n public @Override MutObjBoolPair<T> second(boolean second) {\n this.second = second;\n return this;\n }\n \n\n\n\n\n\n\n\n\n\n\n\n\n }\n\n\n\n\n\n\n public static <T extends Comparable<? super T>> MutCompObjBoolPair<T> comparableOf() { \n return comparableOf( null , false );\n }\n \n\n public static <T extends Comparable<? super T>> MutCompObjBoolPair<T> comparableOf(T a1,boolean a2){\n return new MutCompObjBoolPair(a1,a2);\n }\n\n public static <T extends Comparable<? super T>> MutCompObjBoolPair<T> comparableCopyOf(LObjBoolPair<T> tuple) {\n return comparableOf(tuple.first(), tuple.second());\n }\n\n\n /**\n * Mutable, comparable tuple.\n */\n\n final class MutCompObjBoolPair<T extends Comparable<? super T>> extends AbstractObjBoolPair<T> implements ComparableObjBoolPair<T>,Mut<T,MutCompObjBoolPair<T>> {\n\n private T first;\n private boolean second;\n\n public MutCompObjBoolPair(T a1,boolean a2){\n this.first = a1;\n this.second = a2;\n }\n\n\n public @Override T first() {\n return first;\n }\n\n public @Override MutCompObjBoolPair<T> first(T first) {\n this.first = first;\n return this;\n }\n \n public @Override boolean second() {\n return second;\n }\n\n public @Override MutCompObjBoolPair<T> second(boolean second) {\n this.second = second;\n return this;\n }\n \n\n\n\n\n\n\n\n\n\n\n\n\n }\n\n\n\n\n\n\n\n public static <T> ImmObjBoolPair<T> immutableOf(T a1,boolean a2){\n return new ImmObjBoolPair(a1,a2);\n }\n\n public static <T> ImmObjBoolPair<T> immutableCopyOf(LObjBoolPair<T> tuple) {\n return immutableOf(tuple.first(), tuple.second());\n }\n\n\n /**\n * Immutable, non-comparable tuple.\n */\n@Immutable\n final class ImmObjBoolPair<T> extends AbstractObjBoolPair<T> {\n\n private final T first;\n private final boolean second;\n\n public ImmObjBoolPair(T a1,boolean a2){\n this.first = a1;\n this.second = a2;\n }\n\n\n public @Override T first() {\n return first;\n }\n\n public @Override boolean second() {\n return second;\n }\n\n\n\n }\n\n\n\n\n\n\n\n public static <T extends Comparable<? super T>> ImmCompObjBoolPair<T> immutableComparableOf(T a1,boolean a2){\n return new ImmCompObjBoolPair(a1,a2);\n }\n\n public static <T extends Comparable<? super T>> ImmCompObjBoolPair<T> immutableComparableCopyOf(LObjBoolPair<T> tuple) {\n return immutableComparableOf(tuple.first(), tuple.second());\n }\n\n\n /**\n * Immutable, comparable tuple.\n */\n@Immutable\n final class ImmCompObjBoolPair<T extends Comparable<? super T>> extends AbstractObjBoolPair<T> implements ComparableObjBoolPair<T> {\n\n private final T first;\n private final boolean second;\n\n public ImmCompObjBoolPair(T a1,boolean a2){\n this.first = a1;\n this.second = a2;\n }\n\n\n public @Override T first() {\n return first;\n }\n\n public @Override boolean second() {\n return second;\n }\n\n\n\n }\n\n\n\n}", "public void method_217(boolean var1) {}", "boolean mo54429b();", "public final void mo66089a(boolean z) {\n }", "boolean mo38970a();", "public final void mo5392bA(boolean z) {\n }", "public interface ay {\n void m397a(C0197a c0197a, boolean z);\n\n void m398a(C0198b c0198b, boolean z);\n\n void m399a(C0199c c0199c, boolean z);\n\n void m400a(C0200d c0200d, boolean z);\n\n boolean m401a();\n\n boolean m402b();\n\n byte[] m403c();\n\n String m404d();\n}", "void mo28195a(C5670a aVar, boolean z);", "public abstract boolean a(C c);", "public void a(boolean paramBoolean)\r\n/* 593: */ {\r\n/* 594:593 */ this.k = paramBoolean;\r\n/* 595: */ }", "public abstract boolean mo9230aE();", "public interface C10555f {\n /* renamed from: es */\n void mo22049es(boolean z);\n }", "public void set(boolean[] abol);", "public void ae(boolean z) {\n }", "public void mo97907c(boolean z) {\n }", "public abstract C0631bt mo9251e(boolean z);", "boolean mo44967d();", "final void a(boolean paramBoolean) {\n/* 14387 */ this.d = true;\n/* */ }", "public interface a {\n void cp(boolean z);\n }", "public final void mo91704a(boolean z, boolean z2, boolean z3) {\n }", "protected boolean func_70814_o() { return true; }", "public boolean b(atr paramatr)\r\n/* 468: */ {\r\n/* 469:481 */ if (paramatr.r().l()) {\r\n/* 470:482 */ return true;\r\n/* 471: */ }\r\n/* 472:485 */ amj localamj = a(this.c);\r\n/* 473:486 */ if (localamj != null) {\r\n/* 474:487 */ return localamj.b(paramatr);\r\n/* 475: */ }\r\n/* 476:489 */ return false;\r\n/* 477: */ }", "boolean mo34114a();", "public boolean isGeneralTuple();", "void mo4828a(C0152fo foVar, boolean z);", "public void b(boolean paramBoolean)\r\n/* 184: */ {\r\n/* 185:183 */ this.g = paramBoolean;\r\n/* 186: */ }", "void mo717a(boolean z) throws RemoteException;", "Boolean getBoolean(int col_num);", "private final boolean m42355b(int i) {\n return i == 0;\n }", "public boolean a(World paramaqu, Random paramRandom, BlockPosition paramdt, Block parambec)\r\n/* 72: */ {\r\n/* 73: 88 */ return true;\r\n/* 74: */ }", "boolean mo30282b();", "boolean m19262a(boolean z) {\n return complete(null, null, z ? 8 : 4);\n }", "public Block a(Block parambec, IBlockAccess paramard, BlockPosition paramdt)\r\n/* 18: */ {\r\n/* 19: 33 */ BlockType localatr = paramard.getBlock(paramdt.up()).getType();\r\n/* 20: 34 */ return parambec.setData(a, Boolean.valueOf((localatr == BlockList.aJ) || (localatr == BlockList.aH)));\r\n/* 21: */ }", "public boolean b(alq paramalq)\r\n/* 259: */ {\r\n/* 260:278 */ int i = c(paramalq);\r\n/* 261:279 */ if (i < 0) {\r\n/* 262:280 */ return false;\r\n/* 263: */ }\r\n/* 264:283 */ return true;\r\n/* 265: */ }", "public abstract boolean mo9735b();", "private boolean m223a() {\n if (!at.d(this.f82006a)) {\n if (at.f(this.f82006a) && !c()) {\n return true;\n }\n if ((at.g(this.f82006a) && !b()) || at.h(this.f82006a)) {\n return true;\n }\n }\n return false;\n }", "boolean internal();", "public boolean b(IBlockAccess paramard, BlockPosition paramdt)\r\n/* 31: */ {\r\n/* 32:46 */ return true;\r\n/* 33: */ }", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "public void ad(boolean z, int i) {\n }", "public void mo3375q(boolean z) {\n }", "private boolean m14065a(ap apVar, ap apVar2) {\n return this.f13249m.booleanValue() && apVar.c().equals(ap.f6876a) && apVar.e() == apVar2.e();\n }", "public final void mo71536f(boolean z) {\n }" ]
[ "0.69998014", "0.6941975", "0.6877194", "0.68694633", "0.6867605", "0.6783692", "0.678147", "0.6761459", "0.67188764", "0.66876304", "0.6674321", "0.66666025", "0.6629667", "0.6616609", "0.65896684", "0.65714294", "0.6536081", "0.650516", "0.6498473", "0.64132905", "0.6399977", "0.63559526", "0.6346329", "0.6336688", "0.6308362", "0.62971437", "0.6225537", "0.62211", "0.6216347", "0.62017363", "0.61884487", "0.61763054", "0.6173245", "0.6169279", "0.6167666", "0.6137476", "0.6104423", "0.60995364", "0.6097498", "0.60914695", "0.6084064", "0.60740674", "0.60608876", "0.60506356", "0.60399145", "0.6025696", "0.60077965", "0.6000442", "0.59929657", "0.596735", "0.5955451", "0.5945132", "0.59223557", "0.58624095", "0.5854497", "0.5851774", "0.58353174", "0.58318096", "0.58275115", "0.58238655", "0.58188105", "0.58176535", "0.58175313", "0.5811947", "0.5811252", "0.5807974", "0.5803579", "0.58018696", "0.57999057", "0.5797313", "0.57838756", "0.5781622", "0.5767597", "0.57673156", "0.5760533", "0.5756426", "0.57488906", "0.5745932", "0.57376015", "0.573586", "0.57343924", "0.572642", "0.572476", "0.5694561", "0.5693154", "0.5685666", "0.5680695", "0.56773674", "0.56759185", "0.56671816", "0.56666386", "0.5665578", "0.565045", "0.5649983", "0.5649983", "0.5649983", "0.5649983", "0.564679", "0.5646611", "0.5635265", "0.56313026" ]
0.0
-1
$FF: renamed from: a (dt) void
protected void method_2045(class_1045 param1) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo83698a(T t);", "void mo40877a(T t);", "void mo83696a(T t);", "void mo3312a(T t);", "void mo83695a(T t);", "void mo11495a(T t);", "public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }", "void mo16691c(T t);", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public final void mo91715d() {\n }", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "public void mo21878t() {\n }", "public void a() {\r\n }", "public void d() {\n }", "public void mo44053a() {\n }", "@Override\n\tpublic void dtd() {\n\t\t\n\t}", "void mo17013d();", "public void t();", "public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }", "@Override\n\tpublic void a() {\n\t\t\n\t}", "public void mo6944a() {\n }", "void mo20141a();", "public void a() {\n }", "public void a() {\n }", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "public void mo21795T() {\n }", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "public interface C19512d {\n /* renamed from: dd */\n void mo34676dd(int i, int i2);\n }", "void mo54435d();", "void mo28194a();", "public void mo3749d() {\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public void mo97908d() {\n }", "void mo21073d();", "public abstract void mo42329d();", "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public void m23075a() {\n }", "void mo41083a();", "void mo17023d();", "public void mo115188a() {\n }", "void mo28306a();", "void mo54405a();", "void m1864a() {\r\n }", "public void mo21825b() {\n }", "void mo80452a();", "public void mo21779D() {\n }", "void mo84655a();", "@Override\n public void func_104112_b() {\n \n }", "void mo67920a();", "@Override // g.i.a.a\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public void a(android.view.View r18, android.content.Context r19, android.database.Cursor r20) {\n /*\n // Method dump skipped, instructions count: 441\n */\n throw new UnsupportedOperationException(\"Method not decompiled: g.b.g.t0.a(android.view.View, android.content.Context, android.database.Cursor):void\");\n }", "void mo67923b();", "public abstract void mo129841a(CompletableObserver dVar);", "public interface AbstractC16592a {\n /* renamed from: a */\n void mo67920a();\n\n /* renamed from: a */\n void mo67921a(Object obj);\n\n /* renamed from: a */\n void mo67922a(AbstractC32732ag agVar, Throwable th);\n\n /* renamed from: b */\n void mo67923b();\n\n /* renamed from: c */\n void mo67924c();\n }", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "public void mo5248a() {\n }", "public void mo38117a() {\n }", "void mo13368a();", "void mo57277b();", "void element() {}", "void mo22249a();", "public void dor(){\n }", "public final void mo51373a() {\n }", "interface C11601a {\n /* renamed from: tY */\n void mo23327tY(int i);\n }", "@Override // com.tapjoy.internal.gt\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final void a(android.app.Activity r6) {\n /*\n // Method dump skipped, instructions count: 106\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tapjoy.internal.fp.a(android.app.Activity):void\");\n }", "public void mo9233aH() {\n }", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "void mo38026a();", "void mo12634a();", "public void b() {\r\n }", "@Override\r\n\tpublic void a1() {\n\t\t\r\n\t}", "public static void a() {\n\n }", "void mo98969a();", "static void feladat9() {\n\t}", "public interface d {\n void a();\n}", "void mo88521a();", "void mo9693a();", "public void mo12930a() {\n }", "public void mo9137b() {\n }", "private final void i() {\n }", "public void mo2470d() {\n }", "void id() {}", "public abstract void mo56925d();", "interface C4571et<T> {\n /* renamed from: a */\n int mo16684a(T t);\n\n /* renamed from: a */\n T mo16685a();\n\n /* renamed from: a */\n void mo16686a(T t, C4570es esVar, C4499ch chVar) throws IOException;\n\n /* renamed from: a */\n void mo16687a(T t, C4621gg ggVar) throws IOException;\n\n /* renamed from: a */\n boolean mo16688a(T t, T t2);\n\n /* renamed from: b */\n int mo16689b(T t);\n\n /* renamed from: b */\n void mo16690b(T t, T t2);\n\n /* renamed from: c */\n void mo16691c(T t);\n\n /* renamed from: d */\n boolean mo16692d(T t);\n}", "void mo105476a();", "public void mo115190b() {\n }", "void mo80455b();", "public abstract void mo42331g();", "void mo2311a();", "public abstract void mo3994a();", "void mo12143a();", "public interface u {\n t a();\n}", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public void b() {\n }", "public void b() {\n }", "public void mo2740a() {\n }", "public abstract void mo27386d();", "void mo69874a();", "void berechneFlaeche() {\n\t}", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "public interface C5738d<ViewState> {\n /* renamed from: a */\n void mo17615a(ViewState viewstate);\n}", "public void mo21800a() {\n }" ]
[ "0.67385656", "0.66853535", "0.668506", "0.66633064", "0.66047734", "0.65961534", "0.65139574", "0.6497289", "0.64584565", "0.6431531", "0.6420484", "0.62574935", "0.6253882", "0.62273955", "0.62159604", "0.621208", "0.6203558", "0.62033325", "0.61961687", "0.61684585", "0.61650956", "0.61544436", "0.6147096", "0.6147096", "0.6143979", "0.6135364", "0.6125823", "0.6117947", "0.6114792", "0.61106944", "0.61053574", "0.61020494", "0.6094123", "0.6091388", "0.6069204", "0.6067429", "0.60611194", "0.60284346", "0.6020297", "0.6015229", "0.6014129", "0.60089916", "0.6002775", "0.59987766", "0.5994259", "0.59883976", "0.59835184", "0.5974657", "0.59449846", "0.5942454", "0.59379256", "0.5932592", "0.5916038", "0.59041274", "0.5899747", "0.5893453", "0.589184", "0.58867854", "0.58840543", "0.5881256", "0.58769846", "0.58658534", "0.5864411", "0.58605886", "0.5857174", "0.5848135", "0.58475846", "0.58467263", "0.5845745", "0.583917", "0.58347934", "0.5834745", "0.5823079", "0.58128846", "0.58128464", "0.5810032", "0.58095145", "0.5809121", "0.57999915", "0.5799782", "0.5798829", "0.5789231", "0.57870626", "0.5783958", "0.57691854", "0.5767956", "0.5761445", "0.57612544", "0.57516", "0.57515746", "0.5749648", "0.5745923", "0.57450634", "0.57450634", "0.5741657", "0.57381797", "0.5735687", "0.5725727", "0.57256866", "0.5725474", "0.57204145" ]
0.0
-1
$FF: renamed from: c (dt) void
protected void method_2246(class_1045 param1) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public final void mo91715d() {\n }", "void mo16691c(T t);", "void mo80457c();", "public void mo21878t() {\n }", "void mo21073d();", "void mo17012c();", "void mo17013d();", "public static void c0() {\n\t}", "void mo54435d();", "public void mo21795T() {\n }", "public void mo1403c() {\n }", "public void mo97908d() {\n }", "void mo17023d();", "void mo57277b();", "public void mo21779D() {\n }", "void mo67924c();", "public void mo21825b() {\n }", "void mo57278c();", "public void mo3749d() {\n }", "public void c() {\n }", "public void mo44053a() {\n }", "public void mo6944a() {\n }", "void mo80455b();", "void mo28194a();", "public void mo97906c() {\n }", "void mo41083a();", "void mo17021c();", "void mo28306a();", "void mo67923b();", "public void mo56167c() {\n }", "void mo80452a();", "public void mo115190b() {\n }", "void mo41086b();", "void mo54405a();", "public void mo5099c() {\n }", "void mo12638c();", "public abstract void mo42329d();", "void mo21072c();", "public void mo115188a() {\n }", "void mo40877a(T t);", "public void m23075a() {\n }", "void mo119582b();", "void m1864a() {\r\n }", "public void t();", "void mo1493c();", "private final void i() {\n }", "public void mo9137b() {\n }", "void mo11495a(T t);", "void mo84655a();", "void mo83698a(T t);", "@Override\n\tpublic void dtd() {\n\t\t\n\t}", "public abstract void mo27385c();", "public static void c1() {\n\t}", "void mo88524c();", "public abstract void mo27386d();", "static void feladat9() {\n\t}", "public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }", "void mo13368a();", "@Override\n public void func_104112_b() {\n \n }", "void mo5290b(C5102c c5102c);", "public void mo9233aH() {\n }", "public void mo21877s() {\n }", "public void d() {\n }", "public void mo2470d() {\n }", "void mo83696a(T t);", "public void mo21880v() {\n }", "void mo38026a();", "void mo3312a(T t);", "void mo88523b();", "void mo72114c();", "void mo72113b();", "interface C11601a {\n /* renamed from: tY */\n void mo23327tY(int i);\n }", "public void mo21794S() {\n }", "public void mo21879u() {\n }", "void mo98969a();", "public void mo5248a() {\n }", "void mo67920a();", "void mo12634a();", "void mo22249a();", "public abstract void mo56925d();", "void mo9693a();", "void mo83695a(T t);", "void mo88521a();", "public void mo21782G() {\n }", "public void mo38117a() {\n }", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "public void mo21781F() {\n }", "void mo5289a(C5102c c5102c);", "public void mo3376r() {\n }", "public void mo5097b() {\n }", "public void mo2471e() {\n }", "void mo123342a(C48857t tVar);", "public interface C19512d {\n /* renamed from: dd */\n void mo34676dd(int i, int i2);\n }", "public abstract void mo42331g();", "void mo105476a();", "void mo12650d();", "public abstract void mo53562a(C18796a c18796a);", "public void mo23813b() {\n }", "void mo57275a();", "public final void mo11687c() {\n }", "public void mo21789N() {\n }" ]
[ "0.6944802", "0.6905953", "0.6885433", "0.68446153", "0.6805455", "0.67825544", "0.67613906", "0.67359835", "0.67187977", "0.6718133", "0.6717409", "0.6704654", "0.6687367", "0.66823757", "0.66763234", "0.6675396", "0.663298", "0.66190654", "0.6612465", "0.65980047", "0.65842646", "0.6583684", "0.65775186", "0.65753055", "0.65666056", "0.6557781", "0.6549784", "0.6548086", "0.65463334", "0.6533558", "0.6524213", "0.652146", "0.65133625", "0.65099454", "0.64887416", "0.64879483", "0.6487683", "0.64793706", "0.64690113", "0.64524966", "0.64406145", "0.64375794", "0.64354163", "0.64238155", "0.6419886", "0.6418061", "0.641626", "0.64151394", "0.64129037", "0.64097553", "0.6406948", "0.6402789", "0.6396163", "0.6393127", "0.63889104", "0.63864166", "0.6386392", "0.63844883", "0.6365078", "0.6364074", "0.63551193", "0.63530856", "0.6352648", "0.6351883", "0.63499516", "0.6348412", "0.63472366", "0.6344098", "0.63400036", "0.6339141", "0.6332158", "0.63294345", "0.6327387", "0.63244545", "0.631", "0.6305058", "0.6304782", "0.6301451", "0.63009644", "0.63007396", "0.6298415", "0.6279061", "0.62760705", "0.6272719", "0.626599", "0.62655497", "0.62643373", "0.624411", "0.6241915", "0.62416834", "0.6237819", "0.622826", "0.6226537", "0.62240636", "0.62240577", "0.6211152", "0.62079847", "0.6204024", "0.6195499", "0.6191544", "0.6189698" ]
0.0
-1
$FF: renamed from: m () void
protected void method_2247() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void m(int i) {\r\n\t}", "void m1();", "void m1();", "void m22();", "void m2();", "public void m23075a() {\n }", "void m21();", "@Override\r\n\t\tvoid m() {\n\t\t\tSystem.out.println(\"m\");\r\n\t\t}", "public final void m2() {\n\r\n }", "private void m50366E() {\n }", "void m1864a() {\r\n }", "@Override\n\tpublic void m() {\n\t\tSystem.out.println(\"m\");\n\t\t\n\t}", "void m() {\n\t\ti = 0;\r\n\t\tthis.m(\"\");\r\n\t}", "public abstract void m15813a();", "@Override\n\tpublic void m1() {\n\t\t\n\t}", "void mo80455b();", "void mo80452a();", "void mo28194a();", "void mo57277b();", "public void m2() {\n\n\t}", "private void m50367F() {\n }", "abstract void m1();", "public void mo21788M() {\n }", "static void m2(){\n\t}", "public abstract void mo42329d();", "public void int1_m() {\n\t\t\n\t}", "public abstract void mo42331g();", "void mo28306a();", "public abstract void mo27386d();", "void mo41083a();", "public void mo2471e() {\n }", "void mo119582b();", "void mo1506m();", "void mo67923b();", "public void mo6944a() {\n }", "void mo41086b();", "void mo80457c();", "public abstract void mo70713b();", "void mo22249a();", "void mo72113b();", "default void m2() {\n System.out.println(\"I4.m2()\");\n }", "public void mo21825b() {\n }", "public abstract void mo27385c();", "public void mo21779D() {\n }", "public void mo21781F() {\n }", "public abstract void mo42330e();", "void mo54405a();", "void mo38026a();", "public abstract void m1(int a);", "public void mo9137b() {\n }", "void mo13368a();", "public abstract void mo30696a();", "public abstract void mo6549b();", "public abstract void mo27464a();", "public void mo5248a() {\n }", "@Override\n\tpublic void m2() {\n\t\t\n\t}", "public void mo21782G() {\n }", "void m8367a();", "public void mo21787L() {\n }", "void mo88523b();", "public abstract void mo4359a();", "void mo12143a();", "public abstract void mo35054b();", "void mo3193f();", "public void mo21780E() {\n }", "@Override\r\n\t\t\tpublic void m1() {\n\t\t\t\tSystem.out.println(\"We are in method m1\");\r\n\t\t\t}", "void mo84655a();", "void mo21073d();", "public default void m1() {\n System.out.println(\"I4.m1()\");\n }", "void m8368b();", "void mo17023d();", "public void mo97908d() {\n }", "public void mo21877s() {\n }", "void mo57275a();", "void mo72111a();", "public void mo115190b() {\n }", "public abstract void mo3994a();", "void mo54435d();", "public void mo21789N() {\n }", "void mo37810a();", "public void mo21785J() {\n }", "void mo56163g();", "void mo21074e();", "public void mo5097b() {\n }", "public void mo3749d() {\n }", "void mo67920a();", "void mo105476a();", "public void mo44053a() {\n }", "void mo60892a();", "@Override\n\tpublic void m3() {\n\t\t\n\t}", "void mo98969a();", "public abstract void mo2624j();", "public void mo1405e() {\n }", "void mo17012c();", "void mo71b();", "public abstract int mo9741f();", "void mo12634a();", "public abstract void mo102899a();", "public void mo23813b() {\n }", "public void mo21878t() {\n }", "void mo3311a();" ]
[ "0.75735605", "0.7562664", "0.7562664", "0.7556981", "0.7552413", "0.74801886", "0.74766505", "0.73415554", "0.7307122", "0.729439", "0.7289888", "0.72802454", "0.7235511", "0.7230307", "0.72156644", "0.72047305", "0.7158198", "0.71529335", "0.71079004", "0.7106633", "0.71039814", "0.707983", "0.70756024", "0.7034417", "0.7026641", "0.7021903", "0.7017228", "0.7017095", "0.70155746", "0.6973982", "0.697208", "0.6971841", "0.69539005", "0.6937495", "0.69274133", "0.69263345", "0.69175136", "0.69140583", "0.6911664", "0.6907627", "0.69014364", "0.6896258", "0.6889891", "0.68896914", "0.6889026", "0.68778706", "0.6875819", "0.68640184", "0.68520564", "0.68509483", "0.6833693", "0.68285966", "0.6825331", "0.68210644", "0.68168926", "0.6816683", "0.6813331", "0.68049675", "0.68012726", "0.67987466", "0.6794251", "0.6793684", "0.67854667", "0.6771085", "0.6765188", "0.6763352", "0.6762073", "0.675912", "0.6758656", "0.6754459", "0.67522085", "0.6750157", "0.6748827", "0.67469585", "0.6746755", "0.6746338", "0.67415726", "0.6738039", "0.6732883", "0.67230076", "0.67218673", "0.6717776", "0.67153627", "0.67150116", "0.6709166", "0.6707709", "0.67076135", "0.67041624", "0.6703732", "0.67007846", "0.6697674", "0.66964674", "0.6693096", "0.6691757", "0.6686634", "0.66844136", "0.6683054", "0.6680467", "0.6679691", "0.6677989", "0.6676865" ]
0.0
-1
$FF: renamed from: n () vF
public class_1661 method_2248() { return this.field_1820.method_6175(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void n() {\n this.f80658c.a(new f() {\n public void a(Object obj, boolean z) {\n p unused = m.this.f80658c = (p) obj;\n }\n }, \"__ag_of\");\n }", "public xm n()\r\n/* 274: */ {\r\n/* 275:287 */ if ((this.g == null) && (this.h != null) && (this.h.length() > 0)) {\r\n/* 276:288 */ this.g = this.o.a(this.h);\r\n/* 277: */ }\r\n/* 278:290 */ return this.g;\r\n/* 279: */ }", "public int n_()\r\n/* 429: */ {\r\n/* 430:442 */ return this.a.length + 4;\r\n/* 431: */ }", "public int n(){\n return n;\n }", "public abstract int mo9749n();", "public e n() {\r\n return a(this);\r\n }", "public abstract int preN();", "public R visit(SimpleExp n) {\n R _ret=null;\n if(n.f0.which == 0){\n \t Integer temp = (Integer)n.f0.accept(this);\n \t //new\n \t \n \t ArrayList<Integer> newHold = use.get(statementNumber);\n// \t System.out.println(statementNumber);\n \t newHold.add(temp);\n \t use.put(statementNumber, newHold);\n \t \n \t //new\n \t if(temp >= arguments){\n\t \t ArrayList<Integer> hold = live.get(temp);\n\t \t hold.add(statementNumber);\n\t \t live.put(temp, hold);\n \t }\n }else{\n \t if(n.f0.which == 2)\n \t\t notLabel = false;\n \t n.f0.accept(this);\n \t if(n.f0.which == 2)\n \t\t notLabel = true;\n }\n return _ret;\n }", "public String visit(Exp n, int argu)\r\n\t {\r\n\t\t return null;\r\n\t\t \r\n\t }", "public void mo21789N() {\n }", "@Override\r\n public void visit(IntegerLiteral n, functionStruct fStruct) {\r\n \r\n }", "private interface IPsi {\n public double f(int n);\n }", "public void func_70305_f() {}", "public void visit(PrimitiveType n) {\n n.f0.accept(this);\n }", "public abstract void mo24206b(@C5937f C12292n0<? super T> n0Var);", "public MType visit(NotExpression n, MType argu) {\n \tMType _ret = n.f1.accept(this, argu);\n \treturn _ret;\n }", "public Arginfo visit(neqExpression n, Arginfo argu) {\n\t\t Arginfo _ret=null;\n\t int num1=labelctr++;\n\t int num2=labelctr++;\n\t int var=prectr++;\n\t System.out.println(\"BEGIN\\n CJUMP NE \");\n\t n.f0.accept(this, argu);\n\t n.f1.accept(this, argu);\n\t n.f2.accept(this, argu);\n\t \n\t \n\t System.out.println(\" L\"+num1);\n\t System.out.println(\"\\nMOVE TEMP \"+var+\" 1\\nJUMP L\"+num2+\" \");\n\t System.out.println(\"L\"+num1+\"\\nMOVE TEMP \"+var+\" 0\\nJUMP L\"+num2+\" \"+\"L\"+num2+\"\\nNOOP\\nRETURN TEMP \"+var+\"\\nEND\\n\");\n\t return _ret;\n }", "public void visit(UnaryExpressionNotPlusMinus n) {\n n.f0.accept(this);\n }", "public R visit(Operator n) {\n R _ret=null;\n n.f0.accept(this);\n return _ret;\n }", "void mo1507n();", "void mo6247nm(int i);", "E tan(final E n);", "public abstract int mo12574RN(int i);", "public int getN() {\n return n;\n }", "public R visit(Call n) {\n R _ret=null;\n n.f0.accept(this);\n n.f1.accept(this);\n n.f2.accept(this);\n inCall = true;\n n.f3.accept(this);\n if(funcNumber < magicNumber){\n \t funcNumber = magicNumber;\n }\n magicNumber = 0;\n inCall = false;\n n.f4.accept(this);\n return _ret;\n }", "public static void QuestionOne(Node n) {\n\n\n\n }", "int getN();", "public R visit(Temp n) {\n R _ret=null;\n n.f0.accept(this);\n n.f1.accept(this);\n Integer temp = Integer.parseInt(((String)n.f1.f0.tokenImage));\n //new\n \n if(inCall){\n \t magicNumber++;\n \t ArrayList<Integer> newHold = use.get(statementNumber);\n \t newHold.add(temp);\n \t use.put(statementNumber, newHold);\n }\n \n //new\n \n \n if(temp >= arguments){\n\t if(inCall){\n\t \t ArrayList<Integer> hold = live.get(temp);\n\t \t hold.add(statementNumber);\n\t \t live.put(temp, hold);\n\t }\n }\n _ret = (R)temp;\n return _ret;\n }", "public NFA(){}", "protected int t(int n) {\r\n\t\treturn Math.floorDiv(n * (n - 1), 2);\r\n\t}", "public double getN() {\r\n return n;\r\n }", "private static void showvalue(int n) {\n\t\tSystem.out.println(\"n is\"+ n);\r\n\t}", "E cot(final E n);", "java.lang.String getN();", "void mo57277b();", "public R visit(Procedure n) {\n R _ret=null;\n funcNumber = 0;\n notLabel = false;\n String label = (String)n.f0.accept(this);\n notLabel = true;\n namesOfFunctions.add(label);\n n.f1.accept(this);\n n.f2.accept(this);\n entering = true;\n arguments = Integer.parseInt((String)n.f2.f0.tokenImage);\n n.f3.accept(this);\n n.f4.accept(this);\n maxArgu.put(label, funcNumber);\n// System.out.println(label + \" \" + funcNumber );\n return _ret;\n }", "public R visit(Exp n) {\n R _ret=null;\n n.f0.accept(this);\n return _ret;\n }", "public no(np paramnp)\r\n/* 13: */ {\r\n/* 14:30 */ this.b = paramnp;\r\n/* 15: */ }", "public abstract int finalN();", "public abstract boolean mo36211n();", "public abstract int mo9754s();", "public String visit(Operator n, Object argu)\r\n\t {\r\n\t return null;\r\n\t }", "public String visit(NotExpression n, LLVMRedux argu) throws Exception {\n String reg =u.getReg();\n u.println(reg+\" = xor i1 1, \"+n.f1.accept(this, argu));\n return reg;\n }", "public abstract int mo123247f();", "public String visit(Type n, String argu) {\n return n.f0.accept(this, null);\n \n }", "public String visit(NotExpression n, String s) {\n n.f1.accept(this, null);\n return null;\n }", "public static void print (float n) {\n\t\tint i = (int) n;\n\t\tSystem.out.format(\"%8s\", n == i ? String.valueOf(i) : String.valueOf(n));\n\t}", "private double equation(long n) {\n\t\treturn (4d * montoCarlo(n) / n);\n\t}", "NNode(String[] tokenized) {\r\n\t\tthis(NodeTypeEnum.valueOf(tokenized[3]), Integer.parseInt(tokenized[1]), NodeLabelEnum.valueOf(tokenized[4]));\t\t\r\n\t\tfType = NodeFuncEnum.valueOf(tokenized[2]);\r\n\t\tif (tokenized.length > 5) System.out.println(\"ERROR: Too many segments on reading node from file.\");\r\n\t}", "public R visit(BinOp n) {\n R _ret=null;\n String s0 = (String)n.f0.accept(this);\n simple_exp=0;\n String s1 = (String)n.f1.accept(this);\n simple_exp=0;\n String s2 = (String)n.f2.accept(this);\n int temp = new_temp++;\n System.out.println(\"MOVE TEMP \"+temp + \" \"+s0+\" \"+s1+\" \"+s2);\n return (R)(\"TEMP \"+temp);\n }", "E sin(final E n);", "public R visit(Exp n) {\n R _ret=null;\n String s = (String) n.f0.accept(this);\n // if(coming_from_param==1)\n {\n \t// System.out.println(\"check \"+s);\n \t // return _ret;\n }\n return (R)s;\n }", "public QuickUnionUF(int n) {\n nodes = new int[n];\n for(int i = 0; i < n; ++i) {\n nodes[i] = i;\n }\n }", "public Free( Node n ) {\n\t\tsuper( );\n\t\tvar = (Node_Variable) n;\n\t\tisArgument = false;\n\t\tisListed = false;\n\t}", "public void stworzSiec(int n) {\n\t\tneurony = new ArrayList<Neuron>();\n\t\tfor (int i = 0; i < n; i++)\n\t\t\tneurony.add(new Neuron(Ustawienia.TOTAL));\n\t}", "public void visit(UnaryExpression n) {\n n.f0.accept(this);\n }", "private Binomial(int n) {\n N = n;\n }", "public int getN() {\r\n\t\treturn n;\r\n\t}", "public Arginfo visit(NotExpression n, Arginfo argu) {\n Arginfo _ret=null;\n int a=prectr++;\n int l1=labelctr++;\n int l2=labelctr++;\n System.out.println(\"BEGIN\\nCJUMP \");\n n.f0.accept(this, argu);\n n.f1.accept(this, argu);\n System.out.println(\" L\"+l1+\" \");\n System.out.println(\"MOVE TEMP \"+a+\" 0\\nJUMP L\"+l2+\" \");\n System.out.println(\"L\"+l1+\" \");\n System.out.println(\"MOVE TEMP \"+a+\" 1\\nJUMP L\"+l2+\" \");\n System.out.println(\"L\"+l2+\" NOOP\\n RETURN TEMP \"+a+\"\\nEND\\n\");\n return _ret;\n }", "public VariType visit(Type n, Table argu) { \n\t VariType _ret=null;\n\t n.f0.accept(this, argu);\n\t return _ret;\n\t }", "public VariType visit(Expression n, Table argu) {\n\t VariType _ret=null;\n\t _ret = n.f0.accept(this, argu);\n\t return _ret;\n\t }", "public void visit(Literal n) {\n n.f0.accept(this);\n }", "@Override\n\tpublic void nefesAl() {\n\n\t}", "private static BigDecimal simple(final BigDecimal a, final BigDecimal r, final int n)\n {\n return a.multiply(ONE.add(multiply(r, n)));\n }", "public static void passoutNum(int n){\n\t\tpassoutNum(0,n);\n\t}", "@Override\n\tpublic void visit(Null n) {\n\t\t\n\t}", "public Number(int n) \n {\n nn = n; // initailize with the inputed value\n }", "public String visit(Procedure n, Object argu) \r\n\t{\r\n\t\t\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\".text \\n\");\r\n\t\tMipsOutPut.add(n.f0.f0.tokenImage+\": \\n\");\r\n\t MipsOutPut.add(MipsOutPut.Space+\"sw $fp, -8($sp) \\n\");\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"move $fp, $sp \\n\");\r\n int stackLength = (Integer.parseInt(n.f5.f0.tokenImage)+2)*4;\r\n MipsOutPut.add(MipsOutPut.Space+\"subu $sp, $sp, \" +stackLength +\"\\n\");\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"sw $ra, -4($fp) \\n\");\r\n\t\tn.f10.accept(this,argu);\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"lw $ra, -4($fp) \\n\");\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"lw $fp, -8($fp) \\n\");\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"addu $sp, $sp, \" +stackLength +\"\\n\");\r\n\t\tMipsOutPut.add(MipsOutPut.Space+\"j $ra \\n\");\r\n\t\treturn null;\r\n\t}", "public Arginfo visit(TimesExpression n, Arginfo argu) {\n\t \t Arginfo _ret=null;\n\t int num=labelctr++;\n\t System.out.println(\"BEGIN\\nNOOP\\n RETURN TIMES \");\n\t n.f0.accept(this, argu);\n\t n.f1.accept(this, argu);\n\t n.f2.accept(this, argu);\n\t \n\t System.out.println(\"\\nEND\\n\");\n\t return _ret;\n }", "@Override\n public String visit(Label n) {\n // 注意进入这里的只会有开头的标识 Label\n // 屏蔽 Procedure/CJUMP/JUMP/SimpleExp\n String _ret = null;\n Global.outputString += n.f0.tokenImage + \":\";\n return _ret;\n }", "@Override\r\n public void visit(Exp n, Graph argu) {\r\n n.f0.accept(this, argu);\r\n }", "public int getN() {\n\t\treturn n;\n\t}", "public void func_70295_k_() {}", "public abstract int mo12582RV(int i);", "public abstract int mo123248g();", "public final void mo92082N() {\n }", "@Override\n public String visit(NoOpStmt n) {\n String _ret = null;\n Global.outputString += \"nop\\n\";\n return _ret;\n }", "public abstract Member mo23408O();", "public abstract Integer mo36212o();", "public abstract String mo13682d();", "public void visit(Name n) {\n n.f0.accept(this);\n n.f1.accept(this);\n }", "private int nn(int x)\n {\n return x > 0 ? 1 : 0;\n }", "public void mo1406f() {\n }", "public static void print(int n) {}", "public MType visit(Expression n, MType argu) {\n \tMType _ret = n.f0.accept(this, argu);\n \treturn _ret;\n \t}", "void mo56163g();", "public nonzeronatnum(Inatnum natnum) {\n n = natnum.getVal() + 1;\n prev=natnum;\n }", "public abstract void mo42331g();", "public String visit(NotExpression n, Object argu) \n\t{\n\t\tString _ret=null;\n\t if (n.f1.accept(this, argu).equals(\"boolean\"))\n\t \t_ret = \"boolean\";\n\t return _ret;\n\t}", "@Override\n\tpublic void nadar() {\n\t\t\n\t}", "public abstract String mo9239aw();", "public R visit(Goal n) {\n R _ret=null;\n n.f0.accept(this);\n System.out.println(\"MAIN \");\n String s1 = (String)n.f1.accept(this);\n System.out.println(\" \"+\"END\");\n n.f2.accept(this);\n String s3 = (String)n.f3.accept(this); //todo.\n n.f4.accept(this);\n return _ret;\n }", "public LlvmValue visit(ArrayLength n) {\n return null;\n }", "public R visit(BinOp n) {\n R _ret=null;\n n.f0.accept(this);\n Integer temp = (Integer)n.f1.accept(this);\n //new\n \n ArrayList<Integer> newHold = use.get(statementNumber);\n newHold.add(temp);\n use.put(statementNumber, newHold);\n \n //new\n \n \n if(temp >= arguments){\n\t ArrayList<Integer> hold = live.get(temp);\n\t hold.add(statementNumber);\n\t live.put(temp, hold);\n }\n n.f2.accept(this);\n return _ret;\n }", "void mo1761g(int i);", "public void mo21877s() {\n }", "public static Node<Token> makeNPiOverM(double n, double m) {\n Node<Token> piOverTwo = new Node<Token>(OperatorFactory.makeDivide());\n Node<Token> multiply = new Node<Token>(OperatorFactory.makeMultiply());\n\n multiply.addChild(new Node<Token>(new Number(n)));\n multiply.addChild(new Node<Token>(VariableFactory.makePI()));\n\n piOverTwo.addChild(multiply);\n piOverTwo.addChild(new Node<Token>(new Number(m)));\n\n return piOverTwo;\n }", "void mo21075f();", "public Arginfo visit(Expression n, Arginfo argu) {\n Arginfo _ret=null;\n Arginfo temp=n.f0.accept(this, argu);\n \n return temp;\n }", "public static Node<Token> makePiOverN(boolean negative, double n) {\n Node<Token> piOverTwo = new Node<Token>(OperatorFactory.makeDivide());\n Variable pi = VariableFactory.makePI();\n pi.setNegative(negative);\n piOverTwo.addChild(new Node<Token>(pi));\n piOverTwo.addChild(new Node<Token>(new Number(n)));\n return piOverTwo;\n }", "public interface C7446a {\n /* renamed from: rn */\n void mo32046rn(int i);\n }" ]
[ "0.6898091", "0.66345453", "0.65115505", "0.64429957", "0.6404971", "0.63640755", "0.6294649", "0.61268693", "0.5993445", "0.59810567", "0.5918389", "0.5895529", "0.5825866", "0.58134127", "0.5809902", "0.57945323", "0.5790373", "0.5776501", "0.57730293", "0.57511365", "0.5727915", "0.57186663", "0.5716644", "0.57067627", "0.5702122", "0.5701389", "0.5701006", "0.5700282", "0.5699706", "0.5697241", "0.5682297", "0.5675316", "0.5670755", "0.56681174", "0.5665523", "0.56644714", "0.56509346", "0.5645643", "0.56442297", "0.56332374", "0.5619395", "0.56189597", "0.5605531", "0.5603295", "0.5601578", "0.55990726", "0.55939823", "0.5577905", "0.55749136", "0.5572388", "0.5571934", "0.55639863", "0.5559726", "0.5554607", "0.55473244", "0.5545715", "0.5540256", "0.5534182", "0.55332667", "0.55308825", "0.5529899", "0.55249995", "0.5522252", "0.5512959", "0.5510527", "0.5509801", "0.5509739", "0.5506648", "0.5498313", "0.5494792", "0.5489179", "0.54873955", "0.548638", "0.54642683", "0.5462594", "0.5461697", "0.5456192", "0.5453849", "0.5450217", "0.54481965", "0.5441252", "0.54370946", "0.5434531", "0.54245603", "0.54216945", "0.5419682", "0.5417948", "0.5411753", "0.54107535", "0.5402494", "0.53972065", "0.5395397", "0.5393915", "0.5393872", "0.5393863", "0.5392905", "0.5391913", "0.5390005", "0.53898335", "0.53807515", "0.5372175" ]
0.0
-1
$FF: renamed from: b (boolean, vu) void
public void method_2249(boolean param1, class_81 param2) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo1492b(boolean z);", "void mo197b(boolean z);", "public void b(boolean paramBoolean)\r\n/* 603: */ {\r\n/* 604:601 */ this.l = paramBoolean;\r\n/* 605: */ }", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "public void b(boolean paramBoolean)\r\n/* 184: */ {\r\n/* 185:183 */ this.g = paramBoolean;\r\n/* 186: */ }", "void mo6661a(boolean z);", "void mo98208a(boolean z);", "void mo1488a(boolean z);", "void mo99838a(boolean z);", "void mo21069a(boolean z);", "void mo21071b(boolean z);", "abstract void mo956a(boolean z);", "void mo64153a(boolean z);", "void mo3305a(boolean z);", "public abstract void mo9254f(boolean z);", "public void mo97905b(boolean z) {\n }", "void boolean1(boolean a);", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public abstract C0631bt mo9251e(boolean z);", "void mo12636a(boolean z);", "void mo54420a(boolean z, boolean z2);", "public abstract void mo32006dL(boolean z);", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "void mo2508a(bxb bxb);", "void mo9701a(boolean z);", "public void a(boolean paramBoolean)\r\n/* 593: */ {\r\n/* 594:593 */ this.k = paramBoolean;\r\n/* 595: */ }", "void mo28742b(boolean z, int i);", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "@Override\n public void b() {\n }", "void mo54415a(int i, boolean z);", "@Override\n\tpublic void b() {\n\n\t}", "public abstract boolean mo66253b();", "public abstract void mo9806a(int i, boolean z);", "public abstract void mo9246b(C0707b bVar);", "final void a(boolean paramBoolean) {\n/* 14387 */ this.d = true;\n/* */ }", "void mo717a(boolean z) throws RemoteException;", "void mo728b(boolean z) throws RemoteException;", "@Nullable\n /* renamed from: a */\n public abstract C4891ao mo18474a(Object obj, boolean z);", "public void b() {\r\n }", "public boolean method_2153(boolean param1) {\r\n // $FF: Couldn't be decompiled\r\n }", "public abstract void mo70702a(C30989b c30989b);", "@Override\n public void func_104112_b() {\n \n }", "void mo22049es(boolean z);", "void mo18322a(C7252b bVar);", "public interface AbstractC10485b {\n /* renamed from: a */\n void mo64153a(boolean z);\n }", "void mo50321b(C18924b bVar);", "public void method_217(boolean var1) {}", "void mo7439b(C0933b bVar);", "public final void mo5689a(boolean z) {\n }", "public void b() {\n }", "public void b() {\n }", "void mo50320a(C18924b bVar);", "void b();", "public abstract void mo4360a(byte b);", "public void am(boolean z) {\n }", "public void mo97903a(boolean z) {\n }", "protected void a(bug parambug)\r\n/* 35: */ {\r\n/* 36:36 */ this.j.a((bxf)null);\r\n/* 37: */ }", "@Override\n\tpublic void bbb() {\n\t\t\n\t}", "void mo26249mh(boolean z);", "public abstract boolean mo9735b();", "@Override\n\tpublic void b1() {\n\t\t\n\t}", "public void mo97907c(boolean z) {\n }", "void visitBooleanValue(BooleanValue value);", "public abstract void mo32007dM(boolean z);", "public final void mo12411a(boolean z) {\n }", "public void c(@Nullable ij ☃) {\r\n/* 167 */ this.f = ☃;\r\n/* */ }\r\n/* */ \r\n/* */ public void a(boolean ☃) {\r\n/* 171 */ this.e = ☃;\r\n/* */ }", "public abstract void mo32005dK(boolean z);", "public abstract void mo9798a(byte b);", "public void ak(boolean z) {\n }", "public void a(boolean paramBoolean)\r\n/* 80: */ {\r\n/* 81: 83 */ this.splash = paramBoolean;\r\n/* 82: */ }", "public interface btf {\n boolean e();\n}", "void mo100442a(C40429b bVar);", "public boolean b()\r\n {\r\n return false;\r\n }", "protected abstract void a(bru parambru);", "@Override // c.d.a.m.w.n\n public /* bridge */ /* synthetic */ boolean b(byte[] bArr) {\n return true;\n }", "public boolean b()\r\n/* 709: */ {\r\n/* 710:702 */ return this.l;\r\n/* 711: */ }", "void mo2090a(C0455b bVar);", "public interface C10555f {\n /* renamed from: es */\n void mo22049es(boolean z);\n }", "void mo13377a(boolean z, C15943j c15943j);", "public final void mo66089a(boolean z) {\n }", "@ReflectiveMethod(name = \"b\", types = {})\n public boolean b(){\n return (boolean) NMSWrapper.getInstance().exec(nmsObject);\n }", "public abstract void mo70713b();", "void mo7305b(C1070b bVar);", "public abstract boolean a();", "protected void a(int paramInt1, int paramInt2, boolean paramBoolean, yz paramyz) {}", "public void method_2116(class_689 param1, boolean param2) {\r\n // $FF: Couldn't be decompiled\r\n }", "public abstract void mo9244b(C0620bi biVar);", "public interface C11859a {\n void bvs();\n }", "public final void mo91723e(boolean z) {\n }", "public void ae(boolean z) {\n }", "void mo13374a(boolean z, int i, int i2);", "public boolean b()\n {\n return false;\n }", "public boolean b()\n {\n return false;\n }", "void mo83703a(C32456b<T> bVar);", "public interface C26438t {\n /* renamed from: b */\n void mo5959b(boolean z, String str, Bundle bundle);\n}", "public abstract void mo9245b(C0631bt btVar);", "public abstract void mo4368a(int i, boolean z);", "private void e()\r\n/* 273: */ {\r\n/* 274:278 */ this.r = false;\r\n/* 275:279 */ this.s = false;\r\n/* 276:280 */ this.t = false;\r\n/* 277:281 */ this.u = false;\r\n/* 278:282 */ this.v = false;\r\n/* 279: */ }", "public final void mo71536f(boolean z) {\n }", "boolean mo54429b();" ]
[ "0.759768", "0.75332665", "0.72900784", "0.7247988", "0.7221246", "0.7212252", "0.72099376", "0.7161427", "0.7135334", "0.7073073", "0.7061435", "0.70370233", "0.7027363", "0.7015771", "0.6997709", "0.6968819", "0.6931785", "0.6921538", "0.6854874", "0.68529", "0.6826937", "0.68107706", "0.678757", "0.6769274", "0.6756908", "0.6719017", "0.66439456", "0.6625182", "0.66219735", "0.65896344", "0.6580896", "0.656892", "0.6560324", "0.6558282", "0.6551311", "0.65412647", "0.6518905", "0.6518101", "0.6499897", "0.6495097", "0.64747375", "0.64731705", "0.6463742", "0.6448097", "0.64333093", "0.6428447", "0.64107484", "0.64100504", "0.63925993", "0.63736033", "0.63736033", "0.6351388", "0.63486415", "0.6348444", "0.63424116", "0.63417095", "0.63281554", "0.63269126", "0.63204557", "0.63186187", "0.63136744", "0.63134825", "0.62790143", "0.62724066", "0.62602955", "0.62598914", "0.62519455", "0.6251442", "0.6244864", "0.6237635", "0.62255096", "0.6219612", "0.62148315", "0.6211543", "0.62104434", "0.6207413", "0.6204887", "0.62035286", "0.61935145", "0.6186385", "0.61851996", "0.618304", "0.618294", "0.6182733", "0.61774135", "0.61773676", "0.6160435", "0.61556435", "0.6150101", "0.6147395", "0.61373514", "0.61370873", "0.61370873", "0.613551", "0.6122357", "0.61220974", "0.6119993", "0.6101945", "0.60988146", "0.60963064" ]
0.65637916
32
$FF: renamed from: q () void
public void method_2250() { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n\tpublic void q() {\n\n\t}", "static void q4(){\t\n\t}", "static void q8(){\t\n\t}", "static void q7(){\n\t}", "public boolean q_()\r\n/* 178: */ {\r\n/* 179:203 */ return false;\r\n/* 180: */ }", "public interface t {\n void a(q qVar);\n}", "@Override\n\tpublic void myQuack() {\n\n\t}", "public void mo21792Q() {\n }", "public void g() {\n this.f25459e.Q();\n }", "java.lang.String getQ();", "Term getQ();", "void mo63094q();", "public void q() {\n List<String> b2 = this.f80657b.b();\n if (b2 != null) {\n this.l = b2;\n }\n }", "public void setQ ( boolean q ) {\n\n\tthis.q = q;\n }", "public void setQ(int q) {\n this.q = q;\n }", "@Override\n\tpublic void onQaQuestion(QaQuestion arg0, int arg1) {\n\t\t\n\t}", "public void Okay(String q) {\n\tSystem.out.println(\"q = \" + q);\n }", "@Override\n public void quack() {\n System.out.println(\"__NoQuack__\");\n }", "public void f() {\n Message q_ = q_();\n e.c().a(new f(255, a(q_.toByteArray())), getClass().getSimpleName(), i().a(), q_);\n }", "public abstract String mo9752q();", "public void setQ(int q) {\n System.out.println(\"set q is: \" + q);\n this.q = q;\n }", "public interface C7300a {\n void axq();\n }", "@Override\r\n\tpublic void quack() {\n\t\tSystem.out.println(\"I do Quack Quack\");\r\n\t}", "public interface C2195q {\n /* renamed from: a */\n void mo9337a(C2177n<?> nVar, UnobservedTaskException unobservedTaskException);\n }", "public void setQ(java.lang.Integer value) {\n this.q = value;\n }", "public JPQLQuery(ExecutionContext ec, JPQLQuery q)\r\n {\r\n super(ec, q);\r\n }", "public void j() {\n }", "void mo54452q(int i);", "public void mo1974q() throws cf {\r\n }", "public interface Quackable {\n void quack();\n}", "public void mo38850q() {\n }", "@Override\r\n public String getSimbolo() {\n return \"Q\";\r\n }", "@Override\r\n\tpublic void quack() {\n\t\t\r\n\t}", "public void dispQ()\n\t{\n\t\tSystem.out.println(ans);\t\n\t}", "public String toString(){return Q.toString();}", "void Okay(String q);", "@java.lang.Override\n public java.lang.String getQ() {\n java.lang.Object ref = q_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n q_ = s;\n return s;\n }\n }", "private final void i() {\n }", "public void setQq(String qq) {\r\n\t\tthis.qq = qq;\r\n\t}", "public void setQq(String qq) {\n this.qq = qq;\n }", "public int F()\r\n/* 24: */ {\r\n/* 25: 39 */ return aqt.a(0.5D, 1.0D);\r\n/* 26: */ }", "public abstract void mo27386d();", "public void a(eq ☃) {}\r\n/* */ \r\n/* */ \r\n/* */ \r\n/* */ public int k() {\r\n/* 55 */ return 9;\r\n/* */ }", "public interface AbstractC1509Ys0 extends Q31 {\n Object g(Callback callback);\n}", "public void setQq(String qq) {\r\n this.qq = qq;\r\n }", "public abstract void inLineQuery(InlineQuery q);", "public void setQ(int q) {\n/* 590 */ getCOSObject().setInt(COSName.Q, q);\n/* */ }", "public void performQuack(){\n qb.quack();\n }", "public void t();", "public int getQ() {\n/* 579 */ return getCOSObject().getInt(COSName.Q, 0);\n/* */ }", "public interface Quackable extends QuackObeserable{\n public void quack();\n}", "public interface AbstractC1008ba extends JQ {\n void AA9();\n}", "public static void m11235a(C2195q qVar) {\n f8645l = qVar;\n }", "public qEntry() { }", "public void furyo ()\t{\n }", "public void mo97908d() {\n }", "public abstract void mo27464a();", "public abstract void mo70713b();", "public abstract void m15813a();", "public final void mQ() throws RecognitionException {\n try {\n // /Users/devdatta.kulkarni/Documents/Cassandra/apache-cassandra-0.8.6-src/src/java/org/apache/cassandra/cql/Cql.g:543:11: ( ( 'q' | 'Q' ) )\n // /Users/devdatta.kulkarni/Documents/Cassandra/apache-cassandra-0.8.6-src/src/java/org/apache/cassandra/cql/Cql.g:543:13: ( 'q' | 'Q' )\n {\n if ( input.LA(1)=='Q'||input.LA(1)=='q' ) {\n input.consume();\n\n }\n else {\n MismatchedSetException mse = new MismatchedSetException(null,input);\n recover(mse);\n throw mse;}\n\n\n }\n\n }\n finally {\n }\n }", "public void performQuck() {\n\t\tquackBehavior.quack();\n\t}", "public void e() {\n }", "public void onQsExpansionStarted() {\n onQsExpansionStarted(0);\n }", "public final void mQ() throws RecognitionException {\n try {\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:410:11: ( ( 'q' | 'Q' ) )\n // /Users/cbinnig/Workspace/DHBW_FirstDB_Loesung3/src/de/dhbw/db2/firstdb/sql/FirstSQL.g:410:12: ( 'q' | 'Q' )\n {\n if ( input.LA(1)=='Q'||input.LA(1)=='q' ) {\n input.consume();\n\n }\n else {\n MismatchedSetException mse = new MismatchedSetException(null,input);\n recover(mse);\n throw mse;}\n\n\n }\n\n }\n finally {\n }\n }", "public abstract void mo957b();", "myQueue(){\n }", "@java.lang.Override\n public com.google.protobuf.ByteString\n getQBytes() {\n java.lang.Object ref = q_;\n if (ref instanceof java.lang.String) {\n com.google.protobuf.ByteString b = \n com.google.protobuf.ByteString.copyFromUtf8(\n (java.lang.String) ref);\n q_ = b;\n return b;\n } else {\n return (com.google.protobuf.ByteString) ref;\n }\n }", "public void o_() {}", "public void f() {\n if (this instanceof b) {\n b bVar = (b) this;\n Message q_ = bVar.q_();\n e.c().a(new f(bVar.b(), q_.toByteArray()), getClass().getSimpleName(), i().a(), q_);\n return;\n }\n f a2 = a();\n if (a2 != null) {\n e.c().a(a2, getClass().getSimpleName(), i().a(), (Message) null);\n }\n }", "public baconhep.TTau.Builder setQ(int value) {\n validate(fields()[5], value);\n this.q = value;\n fieldSetFlags()[5] = true;\n return this; \n }", "public java.lang.Integer getQ() {\n return q;\n }", "public void m23075a() {\n }", "public void mo3375q(boolean z) {\n }", "public final void zzjk() {\n }", "public java.lang.Integer getQ() {\n return q;\n }", "private static void init(WorkQueue<IMethod> q) {\n q.add(MultiThreadAnalysisUtil.getFakeRoot());\n }", "public interface Quest {\n void embark();\n}", "protected final void parseQ() {\n current = read();\n skipSpaces();\n\n for (;;) {\n switch (current) {\n default:\n return;\n case '+': case '-': case '.':\n case '0': case '1': case '2': case '3': case '4':\n case '5': case '6': case '7': case '8': case '9':\n }\n\n float x1 = parseNumber();\n skipCommaSpaces();\n float y1 = parseNumber();\n skipCommaSpaces();\n float x = parseNumber();\n skipCommaSpaces();\n float y = parseNumber();\n\n smoothQCenterX = x1;\n smoothQCenterY = y1;\n currentX = x;\n currentY = y;\n p.quadTo(smoothQCenterX, smoothQCenterY, currentX, currentY);\n smoothCCenterX = currentX;\n smoothCCenterY = currentY;\n skipCommaSpaces();\n }\n }", "public aql k()\r\n/* 114: */ {\r\n/* 115:126 */ return aql.b;\r\n/* 116: */ }", "protected final void parseq() {\n current = read();\n skipSpaces();\n\n for (;;) {\n switch (current) {\n default:\n return;\n case '+': case '-': case '.':\n case '0': case '1': case '2': case '3': case '4':\n case '5': case '6': case '7': case '8': case '9':\n }\n\n float x1 = parseNumber();\n skipCommaSpaces();\n float y1 = parseNumber();\n skipCommaSpaces();\n float x = parseNumber();\n skipCommaSpaces();\n float y = parseNumber();\n\n smoothQCenterX = currentX + x1;\n smoothQCenterY = currentY + y1;\n currentX += x; \n currentY += y;\n p.quadTo(smoothQCenterX, smoothQCenterY, currentX, currentY);\n smoothCCenterX = currentX;\n smoothCCenterY = currentY;\n\n skipCommaSpaces();\n }\n }", "@Override\r\n\tpublic void quack() {\n\t\tSystem.out.println(\"꽥꽥\");\r\n\t}", "private void ss(){\n }", "public void method_4270() {}", "void mo57277b();", "public List<Literal> query(Literal q) {\n\r\n\t\t\r\n\t\tList<Literal> result = datalogReasoner.query(compiledClauses, q);\r\n\t\t\r\n\t\tLDLPProgramQueryResultDecompiler decompiler = new LDLPProgramQueryResultDecompiler();\r\n\t\t\r\n\t\tresult = decompiler.decompileLiterals(result);\r\n\t\t\t\t\r\n\t\treturn result;\r\n\r\n\r\n\t}", "public void onQueue();", "public interface QProblem<S extends QState, A extends QAction> {\n\n\t/** Replies the alpha constant used in the QLearning algo.\n\t * \n\t * @return alpha\n\t */\n\tpublic float getAlpha();\n\t\n\t/** Replies the gamma constant used in the QLearning algo.\n\t * \n\t * @return gamma\n\t */\n\tpublic float getGamma();\n\n\t/** Replies the rho constant used in the QLearning algo.\n\t * \n\t * @return rho\n\t */\n\tpublic float getRho();\n\t\n\t/** Replies the nu constant used in the QLearning algo.\n\t * \n\t * @return nu\n\t */\n\t/*public float getNu();\n\t\n\t/** Replies the current state of the problem.\n\t * \n\t * @return the current state of the problem.\n\t */\n\tpublic S getCurrentState();\n\n\t/** Replies a randomly selected state of the problem.\n\t * \n\t * @return a randomly selected state of the problem.\n\t */\n\tpublic S getRandomState();\n\n\t/** Replies all the states of the problem.\n\t * \n\t * @return all the states of the problem.\n\t */\n\tpublic List<S> getAvailableStates();\n\n\t/** Replies all the actions available from the given state.\n\t * \n\t * @param state is the selection state\n\t * @return all the actions for the given <var>state</var>.\n\t */\n\tpublic List<A> getAvailableActionsFor(S state);\n\t\n\t/** \n\t * Evaluate the action executed from the given state and replies\n\t * the feedback.\n\t * \n\t * @param state\n\t * @param action\n\t * @return the feedback\n\t */\n\tpublic QFeedback<S> takedAction();\n\t\n}", "@Test \r\n\tpublic void testQParse() throws ParseError, IOException {\n\t\t\r\n\r\n\r\n\t}", "public abstract void mo42330e();", "public abstract void mo102899a();", "public abstract void p1();", "com.google.protobuf.ByteString\n getQBytes();", "@Override\n\tpublic void QuestionDone() {\n\t\t\n\t}", "public abstract void mo42329d();", "public java.lang.String getQ() {\n java.lang.Object ref = q_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n q_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public void h() {\n }", "private void checkAsk(FyQuestion q, FyAnswer a) {\n\t\treturn;\r\n\t}", "public boolean hasQ() {\n return fieldSetFlags()[5];\n }", "public interface C24340v {\n /* renamed from: q */\n void mo63094q();\n}", "public abstract void t3();", "public interface QuackBehavior {\n public void quack();\n}" ]
[ "0.8454389", "0.76988995", "0.7474161", "0.725083", "0.69781685", "0.68021613", "0.67574567", "0.6614426", "0.65992254", "0.6553471", "0.6523517", "0.65014696", "0.6459112", "0.64162606", "0.6352966", "0.63169914", "0.63049763", "0.6301719", "0.62129676", "0.6192111", "0.603889", "0.60022587", "0.59729135", "0.593885", "0.5845199", "0.58448094", "0.5822971", "0.5822853", "0.58221215", "0.58035517", "0.57990426", "0.5796864", "0.57933766", "0.5793166", "0.5789752", "0.5773708", "0.5766647", "0.5749403", "0.5724372", "0.5717656", "0.57051694", "0.5702804", "0.5701513", "0.5701032", "0.5693546", "0.56849235", "0.5684603", "0.56791544", "0.56741226", "0.5671663", "0.5660701", "0.5655054", "0.5648975", "0.56181467", "0.56120473", "0.56119806", "0.5598836", "0.5586978", "0.55824506", "0.55609787", "0.55554736", "0.55547476", "0.5546942", "0.55420446", "0.5539531", "0.5538154", "0.5531172", "0.5531129", "0.5527463", "0.5526724", "0.5517274", "0.5517051", "0.5498916", "0.5495612", "0.54909086", "0.5490866", "0.54833007", "0.5483151", "0.5478162", "0.5477832", "0.5477818", "0.54668194", "0.5464866", "0.5458977", "0.54506713", "0.5444216", "0.54429525", "0.54338014", "0.5431954", "0.542442", "0.54234266", "0.54224676", "0.5419549", "0.54193336", "0.54193115", "0.5417193", "0.54163444", "0.5413926", "0.5413901", "0.5411626", "0.54052323" ]
0.0
-1
$FF: renamed from: a () void
protected void method_2251() { this.method_2181(); this.field_1823.method_128(this.field_1824, this.field_1850.method_2383().method_8922()); this.field_1826.method_7081(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void a() {\r\n }", "public void a() {\n }", "public void a() {\n }", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "@Override\n\tpublic void a() {\n\t\t\n\t}", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "public static void a() {\n\n }", "void mo28194a();", "void b();", "public void b() {\r\n }", "public void b() {\n }", "public void b() {\n }", "void mo69874a();", "void mo41083a();", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "void mo22249a();", "void mo28306a();", "void mo80452a();", "void mo67920a();", "void mo38026a();", "void mo13368a();", "void mo84655a();", "void mo98969a();", "void mo12634a();", "@Override\r\n\tpublic void a1() {\n\t\t\r\n\t}", "void mo67923b();", "public void mo6944a() {\n }", "public void m23075a() {\n }", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "void mo54405a();", "void mo88521a();", "void mo9693a();", "void m1864a() {\r\n }", "void mo72111a();", "void mo57277b();", "void mo80455b();", "public interface a {\n void a();\n }", "public interface a {\n void a();\n }", "void mo60892a();", "public abstract void mo3994a();", "void mo12143a();", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "void mo57275a();", "void mo119581a();", "void mo119582b();", "public abstract void mo102899a();", "public abstract void m15813a();", "public static aa a() {\n }", "@Override\n public void b() {\n }", "void mo88523b();", "public void mo44053a() {\n }", "void mo37810a();", "public abstract void mo27464a();", "void mo2311a();", "void mo105476a();", "void mo72113b();", "void mo7350a();", "public abstract int a();", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "void mo41086b();", "void m8367a();", "@Override\n\tpublic void A() {\n\t\t\n\t}", "@Override\n\tpublic void A() {\n\t\t\n\t}", "public abstract void mo30696a();", "public int a()\r\n/* 64: */ {\r\n/* 65:70 */ return this.a;\r\n/* 66: */ }", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public void amethod() {\n\t}", "public String b()\r\n/* 35: */ {\r\n/* 36:179 */ return a();\r\n/* 37: */ }", "public void mo5248a() {\n }", "@Override // com.tapjoy.internal.gt\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final void a(android.app.Activity r6) {\n /*\n // Method dump skipped, instructions count: 106\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tapjoy.internal.fp.a(android.app.Activity):void\");\n }", "@Override\n public void func_104112_b() {\n \n }", "public abstract void mo70713b();", "void mo3311a();", "void mo20141a();", "public void mo8738a() {\n }", "public abstract void mo4359a();", "public void mo115188a() {\n }", "public /* bridge */ /* synthetic */ void mo55094a() {\n super.mo55094a();\n }", "public void mo2740a() {\n }", "public void m51745d() {\n this.f42403b.a();\n }", "@Override\n\tpublic void b() {\n\n\t}", "public void mo38117a() {\n }", "public void t();", "public void a() {\n ((a) this.a).a();\n }", "public final void a() {\n this.f10063c.e();\n this.f10061a = 0;\n this.f10062b = 0;\n }", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "public interface C0069a {\n void a();\n }", "void mo12348a();", "public void mo21825b() {\n }", "public abstract void mo45765b();", "public b a()\r\n/* 12: */ {\r\n/* 13:13 */ return this.a;\r\n/* 14: */ }", "public abstract String a();", "void mo10148a();", "public void func_70305_f() {}", "public abstract T a();", "public void a_Action(){}", "public abstract void mo42329d();", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public abstract void mo53562a(C18796a c18796a);", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }" ]
[ "0.79107445", "0.78255236", "0.78255236", "0.7727885", "0.7669216", "0.7550794", "0.754456", "0.7459449", "0.73919964", "0.7330034", "0.727009", "0.727009", "0.71647185", "0.716131", "0.7148495", "0.7143556", "0.7136695", "0.71353513", "0.7098976", "0.7092969", "0.70882696", "0.7080118", "0.70800936", "0.706691", "0.7057396", "0.70299417", "0.70280564", "0.70092756", "0.70059484", "0.69900703", "0.6979564", "0.6966546", "0.6964148", "0.69510937", "0.6934078", "0.69305056", "0.692738", "0.692738", "0.6922337", "0.68998027", "0.68990463", "0.6890994", "0.6886035", "0.6884146", "0.6883108", "0.6882148", "0.6865676", "0.68462247", "0.6834337", "0.68333536", "0.6804758", "0.67926294", "0.6792133", "0.6787119", "0.6784544", "0.6778904", "0.67687577", "0.676355", "0.67541516", "0.6751319", "0.67431813", "0.67371297", "0.67371297", "0.6734662", "0.6732673", "0.67022353", "0.66939175", "0.66890246", "0.6688928", "0.6684261", "0.6671374", "0.6669257", "0.6667858", "0.666149", "0.6661307", "0.6659022", "0.6643668", "0.66354173", "0.6630668", "0.6622423", "0.6614315", "0.6613123", "0.66051173", "0.6596531", "0.6596489", "0.65936744", "0.6590148", "0.65848637", "0.6582944", "0.65717113", "0.6570797", "0.65704215", "0.65689075", "0.6558252", "0.653956", "0.6537924", "0.6534994", "0.65334064", "0.6529071", "0.6525994", "0.6522428" ]
0.0
-1
$FF: renamed from: a (sa) void
protected void method_2090(class_689 var1) { super.method_2090(var1); this.field_1865.method_9478(var1.method_3845(), var1); String[] var10000 = class_752.method_4253(); class_689[] var3 = var1.method_3955(); String[] var2 = var10000; if(var3 != null) { int var4 = 0; while(var4 < var3.length) { this.field_1865.method_9478(var3[var4].method_3845(), var3[var4]); ++var4; if(var2 == null) { break; } } } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "@Override\n\tpublic void a() {\n\t\t\n\t}", "public void a() {\r\n }", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "public void a() {\n }", "public void a() {\n }", "void mo28194a();", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "void m1864a() {\r\n }", "public static void a() {\n\n }", "public void m23075a() {\n }", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "public void mo6944a() {\n }", "void mo80452a();", "@Override\r\n\tpublic void a1() {\n\t\t\r\n\t}", "public void mo44053a() {\n }", "void mo41083a();", "void mo22249a();", "@Override // com.tapjoy.internal.gt\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final void a(android.app.Activity r6) {\n /*\n // Method dump skipped, instructions count: 106\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tapjoy.internal.fp.a(android.app.Activity):void\");\n }", "void mo28306a();", "public void b() {\r\n }", "void mo69874a();", "void mo38026a();", "void mo13368a();", "public abstract void m15813a();", "void mo12634a();", "public /* bridge */ /* synthetic */ void mo55094a() {\n super.mo55094a();\n }", "void mo84655a();", "public void mo2740a() {\n }", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "final /* synthetic */ void m65927a(Void voidR) {\n this.f56359a.m56689p();\n }", "public void mo5248a() {\n }", "void mo57277b();", "public void amethod() {\n\t}", "public void mo8738a() {\n }", "void mo67920a();", "public abstract void mo3994a();", "void mo54405a();", "public void b() {\n }", "public void b() {\n }", "void mo88521a();", "void mo72111a();", "public abstract void mo27464a();", "public void mo38117a() {\n }", "void mo80455b();", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "void mo98969a();", "public void mo115188a() {\n }", "@Override\n public void func_104112_b() {\n \n }", "public abstract void mo102899a();", "void mo67923b();", "public interface AbstractC17367b {\n /* renamed from: a */\n void mo84655a();\n }", "public final void mo51373a() {\n }", "interface C33292a {\n /* renamed from: a */\n void mo85415a(String str);\n }", "public abstract void mo70713b();", "public interface AbstractC23925a {\n /* renamed from: a */\n void mo105476a();\n }", "void mo9693a();", "@Override\n public void b() {\n }", "@Override\n\tpublic void A() {\n\t\t\n\t}", "@Override\n\tpublic void A() {\n\t\t\n\t}", "void mo57275a();", "void mo119582b();", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public interface AbstractC16592a {\n /* renamed from: a */\n void mo67920a();\n\n /* renamed from: a */\n void mo67921a(Object obj);\n\n /* renamed from: a */\n void mo67922a(AbstractC32732ag agVar, Throwable th);\n\n /* renamed from: b */\n void mo67923b();\n\n /* renamed from: c */\n void mo67924c();\n }", "void mo12143a();", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "public void mo21825b() {\n }", "public interface C4521a {\n /* renamed from: a */\n void mo12348a();\n }", "public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "public abstract void mo30696a();", "void mo2311a();", "void mo72113b();", "void mo60892a();", "@Override // g.i.a.a\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public void a(android.view.View r18, android.content.Context r19, android.database.Cursor r20) {\n /*\n // Method dump skipped, instructions count: 441\n */\n throw new UnsupportedOperationException(\"Method not decompiled: g.b.g.t0.a(android.view.View, android.content.Context, android.database.Cursor):void\");\n }", "public interface a {\n void a();\n }", "public interface a {\n void a();\n }", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "void b();", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "void mo119581a();", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public interface ayt {\n /* renamed from: a */\n int mo1635a(long j, List list);\n\n /* renamed from: a */\n long mo1636a(long j, alb alb);\n\n /* renamed from: a */\n void mo1637a();\n\n /* renamed from: a */\n void mo1638a(long j, long j2, List list, ayp ayp);\n\n /* renamed from: a */\n void mo1639a(ayl ayl);\n\n /* renamed from: a */\n boolean mo1640a(ayl ayl, boolean z, Exception exc, long j);\n}", "public interface AbstractC18255a {\n /* renamed from: a */\n void mo88521a();\n\n /* renamed from: a */\n void mo88522a(String str);\n\n /* renamed from: b */\n void mo88523b();\n\n /* renamed from: c */\n void mo88524c();\n }", "public abstract void mo27386d();", "public abstract void mo53562a(C18796a c18796a);", "public interface C6788a {\n /* renamed from: a */\n void mo20141a();\n }", "void mo88523b();", "public interface C0456a {\n /* renamed from: a */\n void mo2090a(C0455b bVar);\n\n /* renamed from: a */\n boolean mo2091a(C0455b bVar, Menu menu);\n\n /* renamed from: a */\n boolean mo2092a(C0455b bVar, MenuItem menuItem);\n\n /* renamed from: b */\n boolean mo2093b(C0455b bVar, Menu menu);\n }", "public void mo23813b() {\n }", "public abstract java.lang.Object a ( ) {\n/* .annotation system Ldalvik/annotation/Signature; */\n/* value = { */\n/* \"()TT;\" */\n/* } */\n}", "public void mo9137b() {\n }", "public int a()\r\n/* 64: */ {\r\n/* 65:70 */ return this.a;\r\n/* 66: */ }", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "void mo7350a();", "void m8367a();", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}" ]
[ "0.74770063", "0.74485826", "0.74295807", "0.7321482", "0.73168856", "0.73168856", "0.71816194", "0.7129648", "0.7093921", "0.7062436", "0.7040526", "0.70351005", "0.6984904", "0.6957273", "0.6935574", "0.68952936", "0.6885123", "0.6871114", "0.6848909", "0.6844372", "0.6818426", "0.6813281", "0.680989", "0.6798075", "0.67914665", "0.67901915", "0.67864347", "0.67840433", "0.6779781", "0.6770117", "0.67505467", "0.67472714", "0.67401403", "0.6739799", "0.67313623", "0.67292017", "0.6721892", "0.671549", "0.67122734", "0.6704401", "0.6704401", "0.6703901", "0.67025656", "0.67024356", "0.66955155", "0.6694655", "0.6691639", "0.66914994", "0.6688611", "0.6688011", "0.66829485", "0.6681518", "0.6680354", "0.66627336", "0.66576236", "0.6656619", "0.6652673", "0.6648047", "0.6647438", "0.6645369", "0.66412497", "0.66412497", "0.66392976", "0.6633385", "0.66213953", "0.66185635", "0.66175926", "0.6616488", "0.6609633", "0.6599906", "0.65995294", "0.65940523", "0.65919894", "0.65900874", "0.6584012", "0.65831554", "0.6582342", "0.6576975", "0.657648", "0.657648", "0.6573477", "0.65659493", "0.6558267", "0.6552332", "0.65473515", "0.6545024", "0.654138", "0.65327007", "0.65262544", "0.65255755", "0.65161955", "0.65095437", "0.6480172", "0.64755523", "0.6473769", "0.64732575", "0.64704424", "0.64689153", "0.6466566", "0.6462256", "0.6457568" ]
0.0
-1
$FF: renamed from: b (sa) void
protected void method_2091(class_689 var1) { String[] var10000 = class_752.method_4253(); super.method_2091(var1); this.field_1865.method_9481(var1.method_3845()); class_689[] var3 = var1.method_3955(); String[] var2 = var10000; if(var3 != null) { int var4 = 0; while(var4 < var3.length) { this.field_1865.method_9481(var3[var4].method_3845()); ++var4; if(var2 == null) { break; } } } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n public void b() {\n }", "public void b() {\r\n }", "@Override\n\tpublic void b() {\n\n\t}", "@Override\n public void func_104112_b() {\n \n }", "public void b() {\n }", "public void b() {\n }", "@Override\n\tpublic void b1() {\n\t\t\n\t}", "public abstract void mo70713b();", "void mo80455b();", "public void mo115190b() {\n }", "void mo57277b();", "public void mo21825b() {\n }", "@Override\n\tpublic void bbb() {\n\t\t\n\t}", "@Override\n\tpublic void b2() {\n\t\t\n\t}", "void mo2508a(bxb bxb);", "void mo72113b();", "void mo67923b();", "public void mo9137b() {\n }", "void b();", "void mo119582b();", "public final void mo1285b() {\n }", "void mo41086b();", "void mo88523b();", "public final /* bridge */ /* synthetic */ void mo43569b() {\n super.mo43569b();\n }", "public abstract void mo6549b();", "void mo28194a();", "public abstract void mo35054b();", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public abstract void mo70702a(C30989b c30989b);", "public abstract void mo45765b();", "void mo7353b();", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "@Override\n\tpublic void a() {\n\t\t\n\t}", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public void mo23813b() {\n }", "public void m23075a() {\n }", "public void mo5097b() {\n }", "void mo80452a();", "public void mo23438b() {\n }", "void m1864a() {\r\n }", "public static void bi() {\n\t}", "public void a() {\r\n }", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "public /* bridge */ /* synthetic */ void mo55094a() {\n super.mo55094a();\n }", "public void mo6944a() {\n }", "public final void mo8775b() {\n }", "public void mo44053a() {\n }", "public abstract void mo4360a(byte b);", "public abstract void mo957b();", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "@Override\r\n\tpublic void a() {\n\t\t\r\n\t}", "final /* synthetic */ void m65927a(Void voidR) {\n this.f56359a.m56689p();\n }", "void berechneFlaeche() {\n\t}", "public abstract void mo42329d();", "public /* bridge */ /* synthetic */ void mo55095b() {\n super.mo55095b();\n }", "void mo41083a();", "public abstract void mo27386d();", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "public void a() {\n }", "public void a() {\n }", "void mo4833b();", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "public void mo97908d() {\n }", "public void mo5251b() {\n }", "public abstract void mo42331g();", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public final void mo91715d() {\n }", "void mo54405a();", "public void mo115188a() {\n }", "public abstract void mo53562a(C18796a c18796a);", "public abstract void mo27464a();", "public abstract void mo9798a(byte b);", "void mo60893b();", "public abstract void mo102899a();", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "protected void a(bug parambug)\r\n/* 35: */ {\r\n/* 36:36 */ this.j.a((bxf)null);\r\n/* 37: */ }", "public void mo3287b() {\n }", "void mo88521a();", "public final void mo51373a() {\n }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "public abstract void m15813a();", "void mo18322a(C7252b bVar);", "public void mo5248a() {\n }", "public abstract void mo42330e();", "void mo22249a();", "public void mo8738a() {\n }", "@Override\n\tpublic void b() {\n\t\tSystem.out.println(\"b method\");\n\t\t\n\t}", "@Override // com.tapjoy.internal.gt\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public final void a(android.app.Activity r6) {\n /*\n // Method dump skipped, instructions count: 106\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.tapjoy.internal.fp.a(android.app.Activity):void\");\n }", "public void mo2740a() {\n }", "public abstract void mo9246b(C0707b bVar);", "void mo12637b();", "public abstract void mo27385c();", "public abstract void mo30696a();", "public abstract void mo9809b(int i);", "void mo28306a();", "public void method_4270() {}", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "void mo80457c();", "void m8368b();", "public void b(gy ☃) {}\r\n/* */ \r\n/* */ \r\n/* */ \r\n/* */ public void a(gy ☃) {}", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}" ]
[ "0.75962996", "0.7506067", "0.7447421", "0.7439266", "0.73608446", "0.73608446", "0.7276486", "0.72757095", "0.72541773", "0.72318137", "0.72067106", "0.72016996", "0.71972185", "0.7189786", "0.7169862", "0.71424645", "0.7121308", "0.71120584", "0.71007156", "0.70908827", "0.7085935", "0.7078527", "0.7076278", "0.7059338", "0.6983261", "0.6956662", "0.6945493", "0.6934076", "0.6924303", "0.6914274", "0.6893303", "0.68866104", "0.68836343", "0.6873689", "0.6872189", "0.68594354", "0.684671", "0.68461865", "0.68440616", "0.6834256", "0.68281746", "0.68241674", "0.67981136", "0.6790834", "0.67773944", "0.67656714", "0.67648065", "0.6763698", "0.67594314", "0.6740279", "0.6736672", "0.67306876", "0.67164874", "0.67099607", "0.6709097", "0.67047036", "0.6701438", "0.6693423", "0.6692773", "0.6692773", "0.6661918", "0.6656858", "0.664637", "0.6644904", "0.6639268", "0.66380864", "0.66379905", "0.6635554", "0.6628952", "0.6624648", "0.6624061", "0.6620539", "0.66173947", "0.6613606", "0.6607455", "0.6604948", "0.6601558", "0.65970886", "0.65969", "0.6587048", "0.6585623", "0.65844506", "0.658431", "0.65837276", "0.658349", "0.6582154", "0.6581884", "0.65801275", "0.6569302", "0.6560403", "0.65564275", "0.65549725", "0.6553189", "0.6551412", "0.65479785", "0.65424824", "0.65283364", "0.6518635", "0.6517923", "0.651717", "0.65157163" ]
0.0
-1
$FF: renamed from: a (int) sa
public class_689 method_2160(int var1) { return (class_689)this.field_1865.method_9475(var1); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo17016a(int i);", "void mo3767a(int i);", "void mo1747a(int i);", "void mo54406a(int i);", "void m15858a(int i);", "void mo38565a(int i);", "public abstract void mo9733a(int i);", "void mo17007a(int i);", "public abstract C14407a mo11604a(int i);", "void mo27576a(int i);", "public void mo5332a(int i) {\n }", "void mo122221a(int i);", "public void mo44231a(int i) {\n }", "void mo66998a(int i);", "public abstract void mo9804a(int i, C3706s0 s0Var);", "void mo1485a(int i);", "long mo133613a();", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "void mo62991a(int i);", "void mo22044oA(int i);", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "public void mo3350a(int i) {\n }", "void mo26876a(int i);", "public interface C8111a {\n /* renamed from: a */\n long mo25071a(long j);\n\n /* renamed from: a */\n C8438u mo25072a(C8438u uVar);\n\n /* renamed from: a */\n AudioProcessor[] mo25073a();\n\n /* renamed from: b */\n long mo25074b();\n }", "void mo88773a(int i);", "public abstract int mo4307b(int i);", "void mo54407a(int i, int i2);", "void mo1753b(int i);", "public abstract void mo9799a(int i);", "void mo1933b(int i);", "public abstract int a(long j2, int i2);", "void mo3796b(int i);", "public abstract void mo9800a(int i, int i2);", "public abstract int mo12581RU(int i);", "public interface AbstractC33066a {\n /* renamed from: a */\n long mo133613a();\n }", "public abstract int mo9732a();", "public abstract void mo20156a(long j);", "public abstract void mo4361a(int i);", "int mo28885a(int i);", "int mo4095a(int i);", "void mo6888a(int i);", "void mo63037a(int i, int i2);", "public abstract Integer mo36212o();", "public abstract long i();", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public abstract void mo4362a(int i, int i2);", "long mo117970a();", "public void int2_m() {\n\t\t\n\t}", "void mo37668e(int i);", "public abstract void mo102900a(int i, int i2);", "void mo7301a(int i, int i2);", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "public abstract void mo4376b(int i);", "long mo1636a(long j, alb alb);", "public abstract void mo2140a(int i);", "void mo17008a(int i, int i2);", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "public abstract C14407a mo11608b(int i);", "public abstract void mo9734b(int i);", "void m15859a(int i, int i2);", "public abstract void mo4369a(long j);", "long mo20406a();", "void mo12647a(C3333i iVar);", "public abstract int mo9736c(int i);", "long mo49a();", "void mo7438a(int i, int i2);", "void mo17017a(int i, int i2);", "public abstract int mo9797a();", "int mo44964a();", "public a(IntegerLiteralTypeConstructor integerLiteralTypeConstructor) {\n super(0);\n this.a = integerLiteralTypeConstructor;\n }", "Long mo20729a();", "void mo1755d(int i);", "public abstract long mo13679a();", "void mo66999a(int i, int i2);", "void mo54447l(int i);", "public abstract void mo9805a(int i, C3706s0 s0Var, C3625g1 g1Var);", "void mo1754c(int i);", "void mo85a(int i);", "public abstract int mo12582RV(int i);", "public int a() {\n return 366;\n }", "public abstract void mo9801a(int i, long j);", "void mo1491b(int i);", "public abstract int mo12585RY(int i);", "void mo56156a(int i, int i2);", "public abstract int mo12575RO(int i);", "void mo8712a(C9714a c9714a);", "void mo107676a(C45111a aVar);", "void mo30275a(long j);", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public abstract int mo12574RN(int i);", "public interface aml {\n long a(int i);\n}", "void mo25956a(int i);", "void mo54437e(int i);", "long mo25071a(long j);", "static int soma2(int a, int b) {\n\t\tint s = a + b;\r\n\t\treturn s;\r\n\t}", "public int a_(int paramInt)\r\n/* 594: */ {\r\n/* 595:636 */ return 0;\r\n/* 596: */ }", "int mo38567b();", "void mo17022c(int i);", "public abstract void mo9809b(int i);", "public abstract long mo9229aD();", "int mo1756e(int i);" ]
[ "0.64843124", "0.63986874", "0.63956565", "0.6361779", "0.6350975", "0.63315487", "0.6267165", "0.6264137", "0.6238081", "0.6225868", "0.6223757", "0.61928165", "0.61718464", "0.6148282", "0.6119396", "0.60903347", "0.60767967", "0.6068261", "0.6067672", "0.60514516", "0.6049899", "0.60495573", "0.6046147", "0.6032805", "0.6031644", "0.6006114", "0.60045934", "0.59864664", "0.5983877", "0.5978821", "0.5976297", "0.5972794", "0.5961679", "0.59533584", "0.59446865", "0.593752", "0.5935891", "0.5919539", "0.59178895", "0.5914794", "0.590439", "0.58759797", "0.5875308", "0.5864593", "0.5863714", "0.5850223", "0.5845404", "0.58407897", "0.5837235", "0.58370805", "0.5831548", "0.582641", "0.5822716", "0.58207965", "0.58128786", "0.5807854", "0.57956445", "0.57890147", "0.57888734", "0.5785885", "0.57746774", "0.57742786", "0.57731986", "0.5770315", "0.57616156", "0.57597977", "0.57569695", "0.5755453", "0.5755193", "0.575454", "0.5753165", "0.5744644", "0.5742879", "0.5742683", "0.57402056", "0.57374626", "0.57252663", "0.5720472", "0.57196605", "0.57195795", "0.5718855", "0.57186633", "0.5718313", "0.5717067", "0.5712321", "0.57115555", "0.57064754", "0.5706343", "0.57013655", "0.57009774", "0.57008284", "0.56867015", "0.56843674", "0.5682943", "0.56819755", "0.5679164", "0.5675982", "0.56756175", "0.5673131", "0.56695527", "0.5669077" ]
0.0
-1
$FF: renamed from: c (sa) boolean
public boolean method_2088(class_689 param1) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo98208a(boolean z);", "void mo21069a(boolean z);", "void mo6661a(boolean z);", "void mo64153a(boolean z);", "void mo1488a(boolean z);", "public Boolean asBoolean();", "void mo99838a(boolean z);", "void mo1492b(boolean z);", "public abstract boolean read_boolean();", "void mo197b(boolean z);", "void mo3305a(boolean z);", "boolean booleanOf();", "private CheckBoolean() {\n\t}", "abstract public boolean getAsBoolean();", "void mo12636a(boolean z);", "void mo9701a(boolean z);", "void boolean1(boolean a);", "boolean isEBoolean();", "protected boolean func_70814_o() { return true; }", "boolean mo44966c();", "void mo13377a(boolean z, C15943j c15943j);", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "BooleanValue createBooleanValue();", "void mo21071b(boolean z);", "void mo54420a(boolean z, boolean z2);", "public abstract void mo32006dL(boolean z);", "public void mo97907c(boolean z) {\n }", "boolean internal();", "public boolean c()\r\n/* 36: */ {\r\n/* 37:51 */ return false;\r\n/* 38: */ }", "abstract void mo956a(boolean z);", "public abstract boolean mo66253b();", "@ReflectiveMethod(name = \"c\", types = {})\n public boolean c(){\n return (boolean) NMSWrapper.getInstance().exec(nmsObject);\n }", "void mo22049es(boolean z);", "public void mo97903a(boolean z) {\n }", "public void mo97905b(boolean z) {\n }", "boolean mo2803a(boolean z);", "public boolean getBoolean(String name)\n/* */ {\n/* 845 */ return getBoolean(name, false);\n/* */ }", "boolean getBoolean();", "boolean getBoolean();", "boolean hasC();", "boolean getBoolValue();", "boolean getBoolValue();", "BoolOperation createBoolOperation();", "public void method_217(boolean var1) {}", "public boolean isBoolean();", "boolean readBoolean();", "void mo26249mh(boolean z);", "private boolean isLava() {\n/* 317 */ return this.isLava;\n/* */ }", "public void a(boolean ☃) {\r\n/* 64 */ this.ab.b(a, Boolean.valueOf(☃));\r\n/* */ }", "public abstract boolean a();", "public abstract C0631bt mo9251e(boolean z);", "boolean mo44967d();", "boolean hasBool();", "<C> BooleanLiteralExp<C> createBooleanLiteralExp();", "public boolean ci() {\n/* 84 */ return true;\n/* */ }", "public abstract void mo9254f(boolean z);", "private BooleanFunctions()\n {\n }", "public final void mo5689a(boolean z) {\n }", "boolean getValue();", "public abstract boolean mo9234ar();", "boolean mo54431c();", "public Boolean getValue() {\n/* 60 */ return Boolean.valueOf(this.val);\n/* */ }", "public boolean getBoolean();", "public void am(boolean z) {\n }", "public interface Truth {\n\n /**\n * This method has to be implemented to know whether the\n * object implementing this interface should be treated\n * as a Boolean.TRUE value or Boolean.FALSE\n *\n * This interface has been created in order to\n * make it easier to interact with Groovy collections\n * and participate of the Groovy truth\n *\n * @return the boolean representation of the current type\n */\n public Boolean asBoolean();\n\n}", "boolean hasBoolValue();", "public boolean isRequiresTaxCertificate() \n{\nObject oo = get_Value(COLUMNNAME_RequiresTaxCertificate);\nif (oo != null) \n{\n if (oo instanceof Boolean) return ((Boolean)oo).booleanValue();\n return \"Y\".equals(oo);\n}\nreturn false;\n}", "boolean mo54429b();", "public boolean readBoolean()\r\n/* 381: */ {\r\n/* 382:394 */ recordLeakNonRefCountingOperation(this.leak);\r\n/* 383:395 */ return super.readBoolean();\r\n/* 384: */ }", "public boolean sawNonboolean() {\n return nonboolean;\n }", "public abstract boolean mo9735b();", "boolean mo38970a();", "public boolean tom();", "@ZenCodeType.Caster\n @ZenCodeType.Method\n default boolean asBool() {\n \n return notSupportedCast(BasicTypeID.BOOL);\n }", "public abstract void mo32005dK(boolean z);", "boolean mo34114a();", "boolean mo1969a();", "public final boolean func_boolean_a(int var1, int var2) {\n if (this.func_boolean_b(var1, var2)) {\n return true;\n } else if (var2 != 53 && var1 != 8) {\n if (var2 == -8) {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)0);\n return true;\n } else {\n return true;\n }\n } else {\n super.field_class_cb_a.func_void_a(this.field_byte_c, (byte)1);\n return true;\n }\n }", "public final void mo12411a(boolean z) {\n }", "public boolean isProcessed() \n{\nObject oo = get_Value(\"Processed\");\nif (oo != null) \n{\n if (oo instanceof Boolean) return ((Boolean)oo).booleanValue();\n return \"Y\".equals(oo);\n}\nreturn false;\n}", "default boolean asBool() {\n\t\tthrow new EvaluatorException(\"Expecting a bool value\");\n\t}", "boolean mo30282b();", "@Test\n\tpublic void test_returnBooleanFoo_true() {\n\n\t}", "@ReflectiveMethod(name = \"b\", types = {})\n public boolean b(){\n return (boolean) NMSWrapper.getInstance().exec(nmsObject);\n }", "public static boolean bVal( Boolean value ) {\n return value != null && value; \n }", "public abstract boolean a(C c);", "public boolean c()\r\n/* 56: */ {\r\n/* 57: 77 */ return false;\r\n/* 58: */ }", "public Boolean() {\n\t\tsuper(false);\n\t}", "private boolean getBoolean(String paramString, boolean paramBoolean) {\n }", "public abstract void mo32007dM(boolean z);", "@JsSupport( {JsVersion.MOZILLA_ONE_DOT_ONE, \r\n\t\tJsVersion.JSCRIPT_TWO_DOT_ZERO})\r\npublic interface Boolean extends Object {\r\n\t\r\n\t@Constructor void Boolean();\r\n\t\r\n\t@Constructor void Boolean(boolean value);\r\n\t\r\n\t@Constructor void Boolean(Number value);\r\n\t\r\n\t@Constructor void Boolean(String value);\r\n\t\r\n\t@Function boolean valueOf();\r\n\t\r\n}", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public static void main(String[] args) {\n\r\n\r\n\t\t boolean value = true;\r\n\r\n\t\t value = false;\r\n\r\n\t\t System.out.println(\"The value for the Boolean variable is : \"+ value);\r\n\t\r\n\r\n}", "public void ak(boolean z) {\n }", "public native boolean __booleanMethod( long __swiftObject, boolean arg );", "boolean mo1292a() {\n return true;\n }", "@Override\n\tpublic boolean javaMethodBaseWithBooleanRet() {\n\t\treturn false;\n\t}", "boolean mo1835a();", "boolean test() {\n return false; // REPLACE WITH SOLUTION\n }" ]
[ "0.7458771", "0.7409154", "0.7407229", "0.7331707", "0.7255799", "0.72439194", "0.7238652", "0.7227415", "0.72041196", "0.71929336", "0.7184337", "0.7160042", "0.7110553", "0.7050686", "0.7011321", "0.7003536", "0.6999719", "0.6941359", "0.6927208", "0.69218665", "0.69028103", "0.6879991", "0.6879991", "0.6879991", "0.6879991", "0.6879861", "0.68663096", "0.68424994", "0.6819366", "0.68155575", "0.680208", "0.68006307", "0.67960733", "0.6778008", "0.6765979", "0.6746913", "0.673109", "0.67093074", "0.66473854", "0.6627152", "0.6627152", "0.66156673", "0.66018933", "0.66018933", "0.6587961", "0.658568", "0.65838754", "0.6576736", "0.65747404", "0.6572585", "0.65630984", "0.6562347", "0.6554794", "0.65400517", "0.6538088", "0.652941", "0.6513019", "0.6512865", "0.6503097", "0.64912546", "0.6489779", "0.64853394", "0.64733374", "0.6468915", "0.6468595", "0.6467376", "0.64666027", "0.64509064", "0.64417213", "0.6439009", "0.64388794", "0.6438395", "0.6436112", "0.6431693", "0.642593", "0.6419132", "0.6417944", "0.64087045", "0.64012194", "0.63984275", "0.63984114", "0.6397532", "0.6397163", "0.63897216", "0.6388011", "0.63871986", "0.6385697", "0.63808036", "0.63798255", "0.63766253", "0.6371466", "0.6362795", "0.6361326", "0.63551146", "0.63251483", "0.6310949", "0.63088286", "0.63081163", "0.63060737", "0.6302202", "0.62995064" ]
0.0
-1
$FF: renamed from: a (sa, byte) void
public void method_2191(class_689 var1, byte var2) { class_1657 var10000 = this.method_2256(); class_283 var10002 = new class_283; var10002.method_1635(var1, var2); var10000.method_9120(var1, var10002); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public abstract void mo4360a(byte b);", "public interface C1153a {\n /* renamed from: a */\n void mo4520a(byte[] bArr);\n }", "public abstract void mo9798a(byte b);", "public interface C43499b {\n /* renamed from: a */\n void mo8445a(int i, String str, int i2, byte[] bArr);\n}", "public abstract void mo53562a(C18796a c18796a);", "public interface C19351a {\n /* renamed from: b */\n void mo30633b(int i, String str, byte[] bArr);\n }", "public abstract void mo70702a(C30989b c30989b);", "void mo2508a(bxb bxb);", "void mo18322a(C7252b bVar);", "interface C0868a {\n /* renamed from: a */\n void mo3207a(Object obj);\n\n /* renamed from: a */\n void mo3208a(String str, Bundle bundle);\n\n /* renamed from: a */\n void mo3209a(String str, Bundle bundle, ResultReceiver resultReceiver);\n\n /* renamed from: a */\n boolean mo3210a(Intent intent);\n }", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "void mo80452a();", "void mo28194a();", "void mo5290b(C5102c c5102c);", "interface C33292a {\n /* renamed from: a */\n void mo85415a(String str);\n }", "void mo5289a(C5102c c5102c);", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "interface C10331b {\n /* renamed from: a */\n void mo26876a(int i);\n }", "void mo8712a(C9714a c9714a);", "public interface b {\n void H_();\n\n void I_();\n\n void J_();\n\n void a(C0063d dVar);\n\n void a(byte[] bArr);\n\n void b(boolean z);\n }", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "void mo72113b();", "public interface C0303q extends C0291e {\n /* renamed from: a */\n void mo1747a(int i);\n\n /* renamed from: a */\n void mo1749a(C0288c cVar);\n\n /* renamed from: a */\n void mo1751a(byte[] bArr);\n\n /* renamed from: b */\n void mo1753b(int i);\n\n /* renamed from: c */\n void mo1754c(int i);\n\n /* renamed from: d */\n void mo1755d(int i);\n\n /* renamed from: e */\n int mo1756e(int i);\n\n /* renamed from: g */\n int mo1760g();\n\n /* renamed from: g */\n void mo1761g(int i);\n\n /* renamed from: h */\n void mo1763h(int i);\n}", "public interface C11112n {\n /* renamed from: a */\n void mo38026a();\n }", "public abstract void mo70713b();", "public void mo44053a() {\n }", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "void mo18320a(C7251a aVar);", "void mo80455b();", "void mo23492a(C9072a0 a0Var);", "public interface C0141g {\n /* renamed from: a */\n void mo84a();\n\n /* renamed from: a */\n void mo85a(int i);\n\n /* renamed from: a */\n void mo86a(C0163d c0163d);\n\n /* renamed from: a */\n void mo87a(String str);\n\n /* renamed from: a */\n void mo88a(byte[] bArr, int i, int i2);\n\n /* renamed from: b */\n C0139e mo89b();\n}", "public void mo23438b() {\n }", "void mo72111a();", "public void mo6944a() {\n }", "public interface C5482b {\n /* renamed from: a */\n void mo27575a();\n\n /* renamed from: a */\n void mo27576a(int i);\n }", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "void mo57277b();", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "public void mo8738a() {\n }", "public abstract void mo6549b();", "void mo50320a(C18924b bVar);", "@Override\n\tpublic void a() {\n\t\t\n\t}", "public void mo115190b() {\n }", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "public interface C4697a extends C5595at {\n /* renamed from: a */\n void mo12634a();\n\n /* renamed from: a */\n void mo12635a(String str);\n\n /* renamed from: a */\n void mo12636a(boolean z);\n\n /* renamed from: b */\n void mo12637b();\n\n /* renamed from: c */\n void mo12638c();\n }", "void mo88523b();", "public void mo9137b() {\n }", "public void mo21825b() {\n }", "void mo88521a();", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public void mo115188a() {\n }", "public void m23075a() {\n }", "@Override\n public void func_104112_b() {\n \n }", "public interface C5728f {\n /* renamed from: a */\n int mo33223a(C5889d dVar) throws IOException;\n\n /* renamed from: a */\n C5727e mo33224a();\n\n @Deprecated\n /* renamed from: a */\n boolean mo33287a(int i) throws IOException;\n\n int read() throws IOException;\n\n int read(byte[] bArr, int i, int i2) throws IOException;\n}", "void mo41083a();", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "public abstract void mo27464a();", "public interface C4521a {\n /* renamed from: a */\n void mo12348a();\n }", "public void mo9233aH() {\n }", "public interface C0456a {\n /* renamed from: a */\n void mo2090a(C0455b bVar);\n\n /* renamed from: a */\n boolean mo2091a(C0455b bVar, Menu menu);\n\n /* renamed from: a */\n boolean mo2092a(C0455b bVar, MenuItem menuItem);\n\n /* renamed from: b */\n boolean mo2093b(C0455b bVar, Menu menu);\n }", "public interface AbstractC18255a {\n /* renamed from: a */\n void mo88521a();\n\n /* renamed from: a */\n void mo88522a(String str);\n\n /* renamed from: b */\n void mo88523b();\n\n /* renamed from: c */\n void mo88524c();\n }", "public final /* bridge */ /* synthetic */ void mo43566a() {\n super.mo43566a();\n }", "void mo12634a();", "public interface C34379a {\n /* renamed from: a */\n void mo46242a(bmc bmc);\n }", "public void mo5248a() {\n }", "public interface C0237a {\n /* renamed from: a */\n void mo1791a(String str);\n }", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "void mo54405a();", "void mo13368a();", "@Override\n\tpublic void aaa() {\n\t\t\n\t}", "void mo57275a();", "void mo2090a(C0455b bVar);", "public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }", "public void a() {\r\n }", "void m1864a() {\r\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "public interface C11113o {\n /* renamed from: a */\n void mo37759a(String str);\n }", "public void mo5097b() {\n }", "public void mo2740a() {\n }", "public abstract void mo9246b(C0707b bVar);", "interface C23413e {\n /* renamed from: a */\n void mo60902a(AvatarImageWithVerify avatarImageWithVerify);\n\n /* renamed from: a */\n boolean mo60903a(AvatarImageWithVerify avatarImageWithVerify, UserVerify userVerify);\n\n /* renamed from: b */\n void mo60904b(AvatarImageWithVerify avatarImageWithVerify);\n }", "void mo38026a();", "public abstract java.lang.Object a ( ) {\n/* .annotation system Ldalvik/annotation/Signature; */\n/* value = { */\n/* \"()TT;\" */\n/* } */\n}", "public interface C6788a {\n /* renamed from: a */\n void mo20141a();\n }", "void mo67923b();", "public interface C42594c {\n void aFw();\n\n /* renamed from: oA */\n void mo22044oA(int i);\n }", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "public interface AbstractC5208b {\n\n /* renamed from: com.iflytek.voiceads.a.b$a */\n public static final class C5209a implements AbstractC5208b {\n\n /* renamed from: a */\n private final byte[] f22887a;\n\n /* renamed from: b */\n private int f22888b;\n\n C5209a(byte[] bArr) {\n this.f22887a = bArr;\n }\n\n @Override // com.iflytek.voiceads.p619a.AbstractC5208b\n /* renamed from: a */\n public void mo38565a(int i) {\n this.f22888b = i;\n }\n\n @Override // com.iflytek.voiceads.p619a.AbstractC5208b\n /* renamed from: a */\n public byte[] mo38566a() {\n return this.f22887a;\n }\n\n @Override // com.iflytek.voiceads.p619a.AbstractC5208b\n /* renamed from: b */\n public int mo38567b() {\n return this.f22888b;\n }\n }\n\n /* renamed from: a */\n void mo38565a(int i);\n\n /* renamed from: a */\n byte[] mo38566a();\n\n /* renamed from: b */\n int mo38567b();\n}", "public abstract void mo45765b();", "interface C1069a {\n /* renamed from: a */\n C1000w mo7300a(int i);\n\n /* renamed from: a */\n void mo7301a(int i, int i2);\n\n /* renamed from: a */\n void mo7302a(int i, int i2, Object obj);\n\n /* renamed from: a */\n void mo7303a(C1070b bVar);\n\n /* renamed from: b */\n void mo7304b(int i, int i2);\n\n /* renamed from: b */\n void mo7305b(C1070b bVar);\n\n /* renamed from: c */\n void mo7306c(int i, int i2);\n\n /* renamed from: d */\n void mo7308d(int i, int i2);\n }", "void mo119582b();", "void mo7353b();", "void mo100442a(C40429b bVar);", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "void mo1751a(byte[] bArr);", "final /* synthetic */ void m65927a(Void voidR) {\n this.f56359a.m56689p();\n }", "void mo69874a();", "C4932q5 mo19394a(byte[] bArr) throws zzfn;" ]
[ "0.7449423", "0.73466545", "0.7256159", "0.71145535", "0.71050006", "0.704584", "0.683941", "0.683133", "0.6783199", "0.67180616", "0.67059284", "0.66531783", "0.6625854", "0.6599624", "0.6568546", "0.6568431", "0.6564412", "0.65567786", "0.65511656", "0.649797", "0.6494129", "0.64922464", "0.6490859", "0.64849275", "0.6483553", "0.64751166", "0.6472452", "0.64649016", "0.64641404", "0.645673", "0.6440315", "0.6435613", "0.64340055", "0.64285564", "0.6423476", "0.6422324", "0.6419634", "0.6419119", "0.6409849", "0.64077896", "0.6396492", "0.63962734", "0.639621", "0.6394136", "0.6391408", "0.6381376", "0.6381193", "0.63784975", "0.6371179", "0.63692605", "0.63589936", "0.6352288", "0.6344462", "0.6342361", "0.634219", "0.6341665", "0.6338685", "0.6334237", "0.6333561", "0.63329494", "0.63316995", "0.63292456", "0.63213164", "0.631902", "0.6316209", "0.6304264", "0.6303927", "0.62966", "0.62932473", "0.62905514", "0.6284069", "0.62824315", "0.6282158", "0.6282135", "0.62795866", "0.62787765", "0.62763566", "0.6276228", "0.627588", "0.62744397", "0.6270285", "0.6265129", "0.626458", "0.62641007", "0.6262777", "0.6262415", "0.6261546", "0.6261131", "0.62554824", "0.6254463", "0.6253542", "0.62523687", "0.6249848", "0.62486285", "0.6248032", "0.6241102", "0.62399864", "0.62378407", "0.6235857", "0.62357616", "0.6233063" ]
0.0
-1
$FF: renamed from: a (sa, double, double, double, float, boolean, boolean) df
public class_1036 method_2126(class_689 param1, double param2, double param4, double param6, float param8, boolean param9, boolean param10) { // $FF: Couldn't be decompiled }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "double[][] asDouble();", "public void visitColumn(double val);", "public Object convertToCatalyst (Object a, org.apache.spark.sql.catalyst.types.DataType dataType) ;", "void mo130799a(double d);", "public <Q> Q[] asDataArray(Q[] a);", "public Object convertToScala (Object a, org.apache.spark.sql.catalyst.types.DataType dataType) ;", "public interface AbstractC17368c {\n /* renamed from: a */\n void mo84656a(float f);\n }", "private void m2248a(double d, String str) {\n this.f2954c = d;\n this.f2955d = (long) d;\n this.f2953b = str;\n this.f2952a = ValueType.doubleValue;\n }", "public interface C0940d {\n /* renamed from: a */\n void mo3305a(boolean z);\n }", "DataFrame<R,C> mapToDoubles(ToDoubleFunction<DataFrameValue<R,C>> mapper);", "public interface afp {\n /* renamed from: a */\n C0512sx mo169a(C0497si siVar, afj afj, afr afr, Context context);\n}", "public abstract T fromDouble(Double d);", "public void set(double[] ad);", "@Test public void gh1206() {\n execute(new CreateDB(NAME, \"<x>a</x>\"));\n query(\"/* castable as xs:double\", false);\n }", "public void mo30a(jda jda) {\n jda.writeDouble(this.f485a);\n }", "public void mo12432a(double... dArr) {\n AppMethodBeat.m2504i(98886);\n super.mo12432a(dArr);\n this.f1597d = (C46783fa) this.f1595c;\n AppMethodBeat.m2505o(98886);\n }", "public interface C40108b {\n /* renamed from: a */\n void mo99838a(boolean z);\n }", "public void mo12432a(double... dArr) {\n AppMethodBeat.m2504i(98892);\n this.f1594b = Double.TYPE;\n this.f1595c = C16224fe.m24746a(dArr);\n AppMethodBeat.m2505o(98892);\n }", "public void a(long arg16, double arg18, double arg20) {\n }", "DataFrame<R,C> sign();", "@Override\n\tpublic void visit(DoubleType n) {\n\t\t\n\t}", "public abstract double[] toDoubleArray();", "private void functionalInterfacesForDoubleIntLong() {\n double d = 1.0;\n DoubleToIntFunction f1 = x -> 1;\n f1.applyAsInt(d);\n\n }", "DataFrame<R,C> copy();", "public interface C39683a {\n /* renamed from: a */\n int mo98966a(C29296g gVar);\n\n /* renamed from: b */\n int mo98967b(C29296g gVar);\n\n /* renamed from: c */\n float mo98968c(C29296g gVar);\n }", "public abstract double[] getasDouble(int tuple);", "void mo72112a(float f);", "public abstract double read_double();", "void mo84656a(float f);", "B database(S database);", "public void method_889(double var1) {\n this.field_667 = var1;\n }", "public void method_887(double var1) {\n this.field_666 = var1;\n }", "public void setA(double a){\n this.a=a;\n }", "public abstract double getasDouble(int tuple, int val);", "public Boolean getDf() {\n return df;\n }", "public void setDf(Boolean df) {\n this.df = df;\n }", "public void method_883(double var1) {\n this.field_663 = var1;\n }", "public abstract Double getDataValue();", "public java.math.BigDecimal getField_737();", "public void mo4638a(int i, double d) {\n this.f2766a.bindDouble(i, d);\n }", "public interface C1709a<Data> {\n /* renamed from: a */\n Class<Data> mo12943a();\n\n /* renamed from: a */\n Data mo12944a(String str) throws IllegalArgumentException;\n\n /* renamed from: a */\n void mo12945a(Data data) throws IOException;\n }", "public void method_881(double var1) {\n this.field_662 = var1;\n }", "void mo56155a(float f);", "public TupleDesc addDouble(String name) {\n columns.add(new TupleDescItem(Type.DOUBLE, name));\n return this;\n }", "@Override\n\tpublic void visit(DoubleValue arg0) {\n\t\t\n\t}", "public interface DataFrame<R,C> extends DataFrameOperations<R,C,DataFrame<R,C>>, DataFrameIterators<R,C>, DataFrameAlgebra<R,C> {\n /**\n * Checks if this DataFrame is empty, according to its number of rows.\n * @return true if the DataFrame is empty, false otherwise\n */\n boolean isEmpty();\n\n /**\n * Returns the row count for <code>DataFrame</code>\n * @return the row count\n */\n int rowCount();\n\n /**\n * Returns the column count for <code>DataFrame</code>\n * @return the column count\n */\n int colCount();\n\n /**\n * Returns true if this frame operates in parallel mode\n * @return true if parallel mode is enabled\n */\n boolean isParallel();\n\n /**\n * Returns a parallel implementation of the DataFrame\n * @return a parallel implementation of the DataFrame\n */\n DataFrame<R,C> parallel();\n\n /**\n * Returns a sequential implementation of the DataFrame\n * @return a sequential implementation of the DataFrame\n */\n DataFrame<R,C> sequential();\n\n /**\n * Returns a deep copy of this <code>DataFrame</code>\n * @return deep copy of this <code>DataFrame</code>\n */\n DataFrame<R,C> copy();\n\n /**\n * Returns a reference to the output interface for this <code>DataFrame</code>\n * @return the output interface for this <code>DataFrame</code>\n */\n DataFrameOutput<R,C> out();\n\n /**\n * Returns a reference to the content of this DataFrame\n * @return the data access interface for this frame\n */\n DataFrameContent<R,C> data();\n\n /**\n * Returns the row operator for this DataFrame\n * @return the row operator for this DataFrame\n */\n DataFrameRows<R,C> rows();\n\n /**\n * Returns the column operator for this DataFrame\n * @return the column operator for this DataFrame\n */\n DataFrameColumns<R,C> cols();\n\n /**\n * Returns a newly created cursor for random access to elements of this frame\n * @return the newly created cursor for element random access\n */\n DataFrameCursor<R,C> cursor();\n\n /**\n * Returns a reference to the row for the key specified\n * @param rowKey the row key to match\n * @return the matching row\n */\n DataFrameRow<R,C> row(R rowKey);\n\n /**\n * Returns a reference to the column for the key specified\n * @param colKey the column key to match\n * @return the matching column\n */\n DataFrameColumn<R,C> col(C colKey);\n\n /**\n * Returns a reference to a row for the ordinal specified\n * @param rowOrdinal the row ordinal\n * @return the matching row\n */\n DataFrameRow<R,C> rowAt(int rowOrdinal);\n\n /**\n * Returns a reference to a column for the ordinal specified\n * @param colIOrdinal the column ordinal\n * @return the matching column\n */\n DataFrameColumn<R,C> colAt(int colIOrdinal);\n\n /**\n * Returns a stream of values over this DataFrame\n * @return the stream of values over this DataFrame\n */\n Stream<DataFrameValue<R,C>> values();\n\n /**\n * Returns a reference to the fill interface for copy values\n * @return the fill interface for this <code>DataFrame</code>\n */\n DataFrameFill fill();\n\n /**\n * Returns the sign DataFrame of -1, 0, 1 for negative, zero and positive elements\n * @return a DataFrame of -1, 0, 1 for negative, zero and positive elements\n * @see <a href=\"http://en.wikipedia.org/wiki/Signum_function\">Wikiepdia Reference</a>\n */\n DataFrame<R,C> sign();\n\n /**\n * Returns the stats for this <code>DataFrame</code>\n * @return the stats for frame\n */\n Stats<Double> stats();\n\n /**\n * Returns the transpose of this DataFrame\n * @return the transpose of this frame\n */\n DataFrame<C,R> transpose();\n\n /**\n * Returns the rank interface for this <code>DataFrame</code>\n * @return the rank interface for the <code>DataFrame</code>\n */\n DataFrameRank<R,C> rank();\n\n /**\n * Returns the event notification interface for this DataFrame\n * @return the event notification interface\n */\n DataFrameEvents events();\n\n /**\n * Returns the write interface which provides a mechanism to write frames to a data store\n * @return the DataFrame write interface\n */\n DataFrameWrite<R,C> write();\n\n /**\n * Returns an interface that enables this frame to be exported as other types\n * @return the <code>DataFrame</code> export interface\n */\n DataFrameExport export();\n\n /**\n * Returns an interface that can be used to efficiently cap values in the frame\n * @param inPlace true if capping should be applied in place, otherwise cap & copy.\n * @return the DataFrame capping interface\n */\n DataFrameCap<R,C> cap(boolean inPlace);\n\n /**\n * Returns a DataFrame containing the first N rows where N=min(count, frame.rowCount())\n * @param count the max number of rows to capture\n * @return the DataFrame containing first N rows where N=min(count, frame.rowCount())\n */\n DataFrame<R,C> head(int count);\n\n /**\n * Returns a DataFrame containing the last N rows where N=min(count, frame.rowCount())\n * @param count the max number of rows to capture\n * @return the DataFrame containing last N rows where N=min(count, frame.rowCount())\n */\n DataFrame<R,C> tail(int count);\n\n /**\n * Returns a DataFrame containing the first N columns where N=min(count, frame.colCount())\n * @param count the max number of left most columns to include\n * @return the DataFrame containing the first B columns where N=min(count, frame.colCount())\n */\n DataFrame<R,C> left(int count);\n\n /**\n * Returns a DataFrame containing the last N columns where N=min(count, frame.colCount())\n * @param count the max number of right most columns to include\n * @return the DataFrame containing the last N columns where N=min(count frame.colCount())\n */\n DataFrame<R,C> right(int count);\n\n /**\n * Returns the calculation interface for this <code>DataFrame</code>\n * @return the calculation interface for the <code>DataFrame</code>\n */\n DataFrameCalculate<R,C> calc();\n\n /**\n * Returns the Principal Component Analysis interface for this DataFrame\n * @return the PCA interface for this DataFrame\n */\n DataFramePCA<R,C> pca();\n\n /**\n * Returns the DataFrame smoothing interface to apply SMA or an EWMA filter to the data\n * @param inPlace if true, smoothing will be applied to this frame, otherwise copy & smooth.\n * @return the DataFrame smoothing data smoothing interface\n */\n DataFrameSmooth<R,C> smooth(boolean inPlace);\n\n /**\n * Returns a reference to the regression interface for this DataFrame\n * @return the regression interface for this DataFrame\n */\n DataFrameRegression<R,C> regress();\n\n /**\n * Adds all rows & columns from the argument that do not exist in this frame, and applies data for added coordinates\n * @param other the other frame from which to add rows, columns & data that do not exist in this frame\n * @return the resulting frame with additional rows and columns\n */\n DataFrame<R,C> addAll(DataFrame<R,C> other);\n\n /**\n * Updates data in this frame based on update frame provided\n * @param update the DataFrame with updates to apply to this frame\n * @param addRows if true, add any missing row keys from the update\n * @param addColumns if true, add any missing column keys from the update\n * @return the updated DataFrame\n */\n DataFrame<R,C> update(DataFrame<R,C> update, boolean addRows, boolean addColumns);\n\n /**\n * Returns a <code>DataFrame</code> filter that includes a subset of rows and columns\n * @param rowKeys the row key selection\n * @param colKeys the column key selection\n * @return the <code>DataFrame</code> filter containing selected rows & columns\n */\n DataFrame<R,C> select(Iterable<R> rowKeys, Iterable<C> colKeys);\n\n /**\n * Returns a <code>DataFrame</code> selection that includes a subset of rows and columns\n * @param rowPredicate the predicate to select rows\n * @param colPredicate the predicate to select columns\n * @return the <code>DataFrame</code> containing selected rows & columns\n */\n DataFrame<R,C> select(Predicate<DataFrameRow<R,C>> rowPredicate, Predicate<DataFrameColumn<R,C>> colPredicate);\n\n /**\n * Returns a newly created DataFrame with all elements of this frame mapped to booleans\n * @param mapper the mapper function to apply\n * @return the newly created frame\n */\n DataFrame<R,C> mapToBooleans(ToBooleanFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a newly created DataFrame with all elements of this frame mapped to ints\n * @param mapper the mapper function to apply\n * @return the newly created frame\n */\n DataFrame<R,C> mapToInts(ToIntFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a newly created DataFrame with all elements of this frame mapped to longs\n * @param mapper the mapper function to apply\n * @return the newly created frame\n */\n DataFrame<R,C> mapToLongs(ToLongFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a newly created DataFrame with all elements of this frame mapped to doubles\n * @param mapper the mapper function to apply\n * @return the newly created frame\n */\n DataFrame<R,C> mapToDoubles(ToDoubleFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a newly created DataFrame with all elements of this frame mapped to objects\n * @param type the type for mapper function\n * @param mapper the mapper function to apply\n * @return the newly created frame\n */\n <T> DataFrame<R,C> mapToObjects(Class<T> type, Function<DataFrameValue<R,C>,T> mapper);\n\n /**\n * Returns a shallow copy of the DataFrame with the specified column mapped to booleans\n * @param colKey the column key to apply mapping function\n * @param mapper the mapper function to apply\n * @return the new frame\n * @throws DataFrameException if frame is transposed, or column does not exist\n */\n DataFrame<R,C> mapToBooleans(C colKey, ToBooleanFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a shallow copy of the DataFrame with the specified column mapped to ints\n * @param colKey the column key to apply mapping function\n * @param mapper the mapper function to apply\n * @return the new frame\n * @throws DataFrameException if frame is transposed, or column does not exist\n */\n DataFrame<R,C> mapToInts(C colKey, ToIntFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a shallow copy of the DataFrame with the specified column mapped to longs\n * @param colKey the column key to apply mapping function\n * @param mapper the mapper function to apply\n * @return the new frame\n * @throws DataFrameException if frame is transposed, or column does not exist\n */\n DataFrame<R,C> mapToLongs(C colKey, ToLongFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a shallow copy of the DataFrame with the specified column mapped to doubles\n * @param colKey the column key to apply mapping function\n * @param mapper the mapper function to apply\n * @return the new frame\n * @throws DataFrameException if frame is transposed, or column does not exist\n */\n DataFrame<R,C> mapToDoubles(C colKey, ToDoubleFunction<DataFrameValue<R,C>> mapper);\n\n /**\n * Returns a shallow copy of the DataFrame with the specified column mapped to objects\n * @param colKey the column key to apply mapping function\n * @param type the data type for mapped column\n * @param mapper the mapper function to apply\n * @return the new frame\n * @throws DataFrameException if frame is transposed, or column does not exist\n */\n <T> DataFrame<R,C> mapToObjects(C colKey, Class<T> type, Function<DataFrameValue<R,C>,T> mapper);\n\n /**\n * Returns a reference to the factory that creates new DataFrames\n * @return the DataFrame factory\n */\n static DataFrameFactory factory() {\n return DataFrameFactory.getInstance();\n }\n\n /**\n * Returns a reference to the DataFrame read interfavce\n * @return the DataFrame read interface\n */\n static DataFrameRead read() {\n return DataFrameFactory.getInstance().read();\n }\n\n /**\n * Returns an empty DataFrame with zero length rows and columns\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the empty DataFrame\n */\n static <R,C> DataFrame<R,C> empty() {\n return DataFrame.factory().empty();\n }\n\n /**\n * Returns an empty DataFrame with zero length rows and columns\n * @param rowAxisType the row axis key type\n * @param colAxisType the column axis key type\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the empty DataFrame\n */\n static <R,C> DataFrame<R,C> empty(Class<R> rowAxisType, Class<C> colAxisType) {\n return DataFrame.factory().empty(rowAxisType, colAxisType);\n }\n\n /**\n * Returns a DataFrame result by concatenating a selection of frames\n * @param frames the iterable of frames to concatenate\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the concatenated DataFrame\n */\n @SafeVarargs\n static <R,C> DataFrame<R,C> combineFirst(DataFrame<R,C>... frames) {\n return DataFrame.factory().combineFirst(Arrays.asList(frames).iterator());\n }\n\n /**\n * Returns a DataFrame result by concatenating a selection of frames\n * @param frames the iterable of frames to concatenate\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the concatenated DataFrame\n */\n static <R,C> DataFrame<R,C> combineFirst(Iterable<DataFrame<R,C>> frames) {\n return DataFrame.factory().combineFirst(frames.iterator());\n }\n\n /**\n * Returns a DataFrame result by combining multiple frames into one while applying only the first non-null element value\n * If there are intersecting coordinates across the frames, that first non-null value will apply in the resulting frame\n * @param frames the stream of frames to apply\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the concatenated DataFrame\n */\n static <R,C> DataFrame<R,C> combineFirst(Stream<DataFrame<R,C>> frames) {\n return DataFrame.factory().combineFirst(frames.iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating rows from the input frames\n * If there are overlapping row keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate rows\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n @SafeVarargs\n static <R,C> DataFrame<R,C> concatRows(DataFrame<R,C>... frames) {\n return DataFrame.factory().concatRows(Arrays.asList(frames).iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating rows from the input frames\n * If there are overlapping row keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate rows\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n static <R,C> DataFrame<R,C> concatRows(Iterable<DataFrame<R,C>> frames) {\n return DataFrame.factory().concatRows(frames.iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating rows from the input frames\n * If there are overlapping row keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate rows\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n static <R,C> DataFrame<R,C> concatRows(Stream<DataFrame<R,C>> frames) {\n return DataFrame.factory().concatRows(frames.iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating columns from the input frames\n * If there are overlapping column keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate columns\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n @SafeVarargs\n static <R,C> DataFrame<R,C> concatColumns(DataFrame<R,C>... frames) {\n return DataFrame.factory().concatColumns(Arrays.asList(frames).iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating columns from the input frames\n * If there are overlapping column keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate columns\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n static <R,C> DataFrame<R,C> concatColumns(Iterable<DataFrame<R,C>> frames) {\n return DataFrame.factory().concatColumns(frames.iterator());\n }\n\n /**\n * Returns a newly created DataFrame by concatenating columns from the input frames\n * If there are overlapping column keys, the row values from the first frame will apply\n * @param frames the iterable of frames from which to concatenate columns\n * @param <R> the row key type for frames\n * @param <C> the column key type for frames\n * @return the resulting DataFrame\n */\n static <R,C> DataFrame<R,C> concatColumns(Stream<DataFrame<R,C>> frames) {\n return DataFrame.factory().concatColumns(frames.iterator());\n }\n\n /**\n * Returns an empty DataFrame with the row and column types specified\n * @param rowType the row key type\n * @param colType the column key type\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> of(Class<R> rowType, Class<C> colType) {\n return DataFrame.factory().from(Index.of(rowType, 1000), Index.of(colType, 20), Object.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized for columns with the type specified\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param type the data type for columns\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> of(Iterable<R> rowKeys, Iterable<C> colKeys, Class<?> type) {\n return DataFrame.factory().from(rowKeys, colKeys, type);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row and N columns all with the data type specified\n * @param rowKey the row key for frame\n * @param colKeys the column keys for frame\n * @param dataType the data type for columns\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> of(R rowKey, Iterable<C> colKeys, Class<?> dataType) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, dataType);\n }\n\n /**\n * Returns a newly created DataFrame with N rows and 1 column with the data type specified\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param type the data type for columns\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> of(Iterable<R> rowKeys, C colKey, Class<?> type) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), type);\n }\n\n /**\n * Returns a newly created DataFrame initialized with rows and any state added by the consumer\n * @param rowKeys the row keys for frame\n * @param colType the column key type\n * @param columns the consumer which can be used to add columns\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created <code>DataFrame</code>\n */\n static <R,C> DataFrame<R,C> of(Iterable<R> rowKeys, Class<C> colType, Consumer<DataFrameColumns<R,C>> columns) {\n return DataFrame.factory().from(rowKeys, colType, columns);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row optimized to hold primitive booleans\n * @param rowKey the row key for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofBooleans(R rowKey, Iterable<C> colKeys) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, Boolean.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row optimized to hold primitive integers\n * @param rowKey the row key for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofInts(R rowKey, Iterable<C> colKeys) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, Integer.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row optimized to hold primitive longs\n * @param rowKey the row key for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofLongs(R rowKey, Iterable<C> colKeys) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, Long.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row optimized to hold primitive doubles\n * @param rowKey the row key for frame\n * @param colKeys the column index for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofDoubles(R rowKey, Iterable<C> colKeys) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, Double.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 row optimized to hold any object\n * @param rowKey the row key for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofObjects(R rowKey, Iterable<C> colKeys) {\n return DataFrame.factory().from(Index.singleton(rowKey), colKeys, Object.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 column optimized to hold primitive booleans\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofBooleans(Iterable<R> rowKeys, C colKey) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), Boolean.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 column optimized to hold primitive integers\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofInts(Iterable<R> rowKeys, C colKey) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), Integer.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 column optimized to hold primitive longs\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofLongs(Iterable<R> rowKeys, C colKey) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), Long.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 column optimized to hold primitive doubles\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofDoubles(Iterable<R> rowKeys, C colKey) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), Double.class);\n }\n\n /**\n * Returns a newly created DataFrame with 1 column optimized to hold any object\n * @param rowKeys the row keys for frame\n * @param colKey the column key for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofObjects(Iterable<R> rowKeys, C colKey) {\n return DataFrame.factory().from(rowKeys, Index.singleton(colKey), Object.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive booleans\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofBooleans(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, Boolean.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive integers\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofInts(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, Integer.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive longs\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofLongs(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, Long.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive doubles\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofDoubles(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, Double.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold Strings\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofStrings(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, String.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold any objects\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofObjects(Iterable<R> rowKeys, Iterable<C> colKeys) {\n return DataFrame.factory().from(rowKeys, colKeys, Object.class);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive booleans\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param initials a function to provide initial values\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofBooleans(Iterable<R> rowKeys, Iterable<C> colKeys, ToBooleanFunction<DataFrameValue<R,C>> initials) {\n return DataFrame.factory().from(rowKeys, colKeys, Boolean.class).applyBooleans(initials);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive integers\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param initials a function to provide initial values\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofInts(Iterable<R> rowKeys, Iterable<C> colKeys, ToIntFunction<DataFrameValue<R,C>> initials) {\n return DataFrame.factory().from(rowKeys, colKeys, Integer.class).applyInts(initials);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive longs\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param initials a function to provide initial values\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofLongs(Iterable<R> rowKeys, Iterable<C> colKeys, ToLongFunction<DataFrameValue<R,C>> initials) {\n return DataFrame.factory().from(rowKeys, colKeys, Long.class).applyLongs(initials);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold primitive doubles\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param initials a function to provide initial values\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofDoubles(Iterable<R> rowKeys, Iterable<C> colKeys, ToDoubleFunction<DataFrameValue<R,C>> initials) {\n return DataFrame.factory().from(rowKeys, colKeys, Double.class).applyDoubles(initials);\n }\n\n /**\n * Returns a newly created DataFrame optimized to hold any objects\n * @param rowKeys the row keys for frame\n * @param colKeys the column keys for frame\n * @param initials a function to provide initial values\n * @param <R> the row key type\n * @param <C> the column key type\n * @return the newly created DataFrame\n */\n static <R,C> DataFrame<R,C> ofObjects(Iterable<R> rowKeys, Iterable<C> colKeys, Function<DataFrameValue<R, C>, ?> initials) {\n return DataFrame.factory().from(rowKeys, colKeys, Object.class).applyValues(initials);\n }\n\n /**\n * Returns a DataFrame of doubles initialized with ARGB values for each pixel in the image\n * @param file the file to load the image from\n * @return the DataFrame of ARGB values extracted from java.awt.image.BufferedImage\n * @link java.awt.image.BufferedImage#getRGB\n */\n static DataFrame<Integer,Integer> ofImage(File file) {\n try {\n final BufferedImage image = ImageIO.read(file);\n final Range<Integer> rowKeys = Range.of(0, image.getHeight());\n final Range<Integer> colKeys = Range.of(0, image.getWidth());\n return DataFrame.ofInts(rowKeys, colKeys, v -> image.getRGB(v.colOrdinal(), v.rowOrdinal()));\n } catch (Exception ex) {\n throw new DataFrameException(\"Failed to initialize DataFrame from image file: \" + file.getAbsolutePath(), ex);\n }\n }\n\n /**\n * Returns a DataFrame of doubles initialized with ARGB values for each pixel in the image\n * @param url the url to load the image from\n * @return the DataFrame of ARGB values extracted from java.awt.image.BufferedImage\n * @see java.awt.image.BufferedImage#getRGB\n */\n static DataFrame<Integer,Integer> ofImage(URL url) {\n try {\n final BufferedImage image = ImageIO.read(url);\n final Range<Integer> rowKeys = Range.of(0, image.getHeight());\n final Range<Integer> colKeys = Range.of(0, image.getWidth());\n return DataFrame.ofInts(rowKeys, colKeys, v -> image.getRGB(v.colOrdinal(), v.rowOrdinal()));\n } catch (Exception ex) {\n throw new DataFrameException(\"Failed to initialize DataFrame from image url: \" + url, ex);\n }\n }\n\n\n /**\n * Returns a DataFrame of doubles initialized with ARGB values for each pixel in the image\n * @param inputStream the input stream to load the image from\n * @return the DataFrame of ARGB values extracted from java.awt.image.BufferedImage\n * @see java.awt.image.BufferedImage#getRGB\n */\n static DataFrame<Integer,Integer> ofImage(InputStream inputStream) {\n try {\n final BufferedImage image = ImageIO.read(inputStream);\n final Range<Integer> rowKeys = Range.of(0, image.getHeight());\n final Range<Integer> colKeys = Range.of(0, image.getWidth());\n return DataFrame.ofInts(rowKeys, colKeys, v -> image.getRGB(v.colOrdinal(), v.rowOrdinal()));\n } catch (Exception ex) {\n throw new DataFrameException(\"Failed to initialize DataFrame from image input stream\", ex);\n }\n }\n}", "DataFrame<R,C> mapToDoubles(C colKey, ToDoubleFunction<DataFrameValue<R,C>> mapper);", "@Test\n public void newColumn() throws Exception {\n DoubleColumn column = (DoubleColumn) TypeUtils.newColumn(\"test\", DOUBLE);\n assertNotNull(column);\n }", "double getField3();", "public void mo1946a(double d) throws cf {\r\n byte[] bArr = new byte[]{(byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0};\r\n m10260a(Double.doubleToLongBits(d), bArr, 0);\r\n this.g.m10347b(bArr);\r\n }", "public void method_899(double var1) {\n this.field_672 = var1;\n }", "public static void main(String[] args)\n {\n\n double myDouble = 3.14;\n float myFloat = 3.14f; //Removing the f will cause an error due to lossy conversion\n double yourDouble = myFloat; //Widening/lossless conversions won't raise errors\n }", "public interface C43470b {\n /* renamed from: a */\n void mo61496a(C43469a aVar, C43471c cVar);\n }", "private Data[] getDoubles(double value, int npoints, int nattributes)\n\t{\n\t\tData[] data = new Data[npoints];\n\t\tfor (int i = 0; i < npoints; i++)\n\t\t\tdata[i] = nattributes == 1 ? new DataDouble(value)\n\t\t: new DataArrayOfDoubles(new double[] { value, value });\n\t\t\treturn data;\n\t}", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public abstract Double toDouble(T t);", "private static double[] shortToDouble(short[] s, double[] d) {\n for (int i = 0; i < d.length; i++) {\n d[i] = s[i];\n }\n return d;\n }", "public interface DoubleConsumer {\n /* renamed from: a */\n void mo130799a(double d);\n}", "@Override\n\tpublic void visit(DoubleValue arg0) {\n\n\t}", "public Double getDoubleAttribute();", "public interface C0937a {\n /* renamed from: a */\n void mo3807a(C0985po[] poVarArr);\n }", "public void dorbdb_(CHARACTER TRANS,CHARACTER SIGNS,INTEGER M,INTEGER P,INTEGER Q,double[] X11,INTEGER LDX11,double[] X12,INTEGER LDX12,double[] X21,INTEGER LDX21,double[] X22,INTEGER LDX22,double[] THETA,double[] PHI,double[] TAUP1,double[] TAUP2,double[] TAUQ1,double[] TAUQ2,double[] WORK,INTEGER LWORK,INTEGER INFO);", "static Nda<Double> of( double... value ) { return Tensor.of( Double.class, Shape.of( value.length ), value ); }", "public interface C5861g {\n /* renamed from: a */\n void mo18320a(C7251a aVar);\n\n @Deprecated\n /* renamed from: a */\n void mo18321a(C7251a aVar, String str);\n\n /* renamed from: a */\n void mo18322a(C7252b bVar);\n\n /* renamed from: a */\n void mo18323a(C7253c cVar);\n\n /* renamed from: a */\n void mo18324a(C7260j jVar);\n}", "public void method_871(double var1) {\n this.field_657 = var1;\n }", "void mo9704b(float f, float f2, int i);", "public interface BoxedDoubleToBooleanFunction extends ObjectToBooleanFunction<Double> {\n\n}", "public interface C5882b {\n /* renamed from: a */\n void mo28194a();\n\n /* renamed from: a */\n void mo28195a(C5670a aVar, boolean z);\n }", "@Test\n public void testAliasedTableColumns()\n {\n assertEquals(\n runner.execute(\"SELECT * FROM orders AS t (a, b, c, d, e, f, g, h, i)\"),\n runner.execute(\"SELECT * FROM orders\"));\n }", "public void method_893(Double var1) {\n this.field_669 = var1;\n }", "boolean mo61590s(double d);", "void setDouble(int index, double value) throws SQLException;", "public DataPrimitive(double value) {\n\t\tsuper();\n\t\tthis.value = Double.toString(value);\n\t}", "public Flt(float f) {this.f = new Float(f);}", "DataSet toDataSet(Object adaptee);", "public interface C27084a {\n /* renamed from: a */\n void mo69874a();\n\n /* renamed from: a */\n void mo69875a(List<Aweme> list, boolean z);\n }", "public float d()\r\n/* 15: */ {\r\n/* 16:163 */ return this.b;\r\n/* 17: */ }", "public void method_897(double var1) {\n this.field_671 = var1;\n }", "public MutableArray(double[] paramArrayOfDouble, int paramInt, CustomDatumFactory paramCustomDatumFactory)\n/* */ {\n/* 191 */ this.sqlType = paramInt;\n/* 192 */ this.old_factory = paramCustomDatumFactory;\n/* 193 */ this.isNChar = false;\n/* */ \n/* 195 */ setArray(paramArrayOfDouble);\n/* */ }", "public interface C0159fv {\n /* renamed from: a */\n void mo4827a(Context context, C0152fo foVar);\n\n /* renamed from: a */\n void mo4828a(C0152fo foVar, boolean z);\n\n /* renamed from: a */\n void mo4829a(C0158fu fuVar);\n\n /* renamed from: a */\n boolean mo4830a();\n\n /* renamed from: a */\n boolean mo4831a(C0153fp fpVar);\n\n /* renamed from: a */\n boolean mo4832a(C0167gc gcVar);\n\n /* renamed from: b */\n void mo4833b();\n\n /* renamed from: b */\n boolean mo4834b(C0153fp fpVar);\n}", "private SRTLabTestDT convertToSRTLabTestDT(TestResultTestFilterDT oldDT){\n SRTLabTestDT newDT = new SRTLabTestDT(oldDT);\n return newDT;\n\n }", "public interface MultiValueTableAdapter {\n\t//public void setComplexTable( ComplexTable table );\n\tpublic Object[] extract( Object o );\n\tpublic Object extractEvenNoValueExist( Object o );\n\tpublic void combine( Object o, Object[] extractValues );\n\tpublic ObjectNewer getObjectNewer();\n}", "public static Double[] convertirTableau(ArrayList<Double> valeurs) {\n\t\tDouble[] tab = new Double[valeurs.size()];\n\t\tfor(int i = 0; i <valeurs.size(); i++) {\n\t\t\ttab[i] = valeurs.get(i);\n\t\t}\n\t\treturn tab;\n\t}", "public interface C5663B {\n\n /* renamed from: a */\n public static final Integer f9595a = Integer.valueOf(1);\n\n /* renamed from: b */\n public static final Integer f9596b = Integer.valueOf(2);\n\n /* renamed from: c */\n public static final Integer f9597c = Integer.valueOf(3);\n\n /* renamed from: d */\n public static final Integer f9598d = Integer.valueOf(4);\n\n /* renamed from: e */\n public static final PointF f9599e = new PointF();\n\n /* renamed from: f */\n public static final PointF f9600f = new PointF();\n\n /* renamed from: g */\n public static final PointF f9601g = new PointF();\n\n /* renamed from: h */\n public static final PointF f9602h = new PointF();\n\n /* renamed from: i */\n public static final C5834d f9603i = new C5834d();\n\n /* renamed from: j */\n public static final Float f9604j = Float.valueOf(1.0f);\n\n /* renamed from: k */\n public static final Float f9605k = Float.valueOf(2.0f);\n\n /* renamed from: l */\n public static final Float f9606l = Float.valueOf(3.0f);\n\n /* renamed from: m */\n public static final Float f9607m = Float.valueOf(4.0f);\n\n /* renamed from: n */\n public static final Float f9608n = Float.valueOf(5.0f);\n\n /* renamed from: o */\n public static final Float f9609o = Float.valueOf(6.0f);\n\n /* renamed from: p */\n public static final Float f9610p = Float.valueOf(7.0f);\n\n /* renamed from: q */\n public static final Float f9611q = Float.valueOf(8.0f);\n\n /* renamed from: r */\n public static final Float f9612r = Float.valueOf(9.0f);\n\n /* renamed from: s */\n public static final Float f9613s = Float.valueOf(10.0f);\n\n /* renamed from: t */\n public static final Float f9614t = Float.valueOf(11.0f);\n\n /* renamed from: u */\n public static final Float f9615u;\n\n /* renamed from: v */\n public static final Float f9616v;\n\n /* renamed from: w */\n public static final Float f9617w = Float.valueOf(13.0f);\n\n /* renamed from: x */\n public static final ColorFilter f9618x = new ColorFilter();\n\n static {\n Float valueOf = Float.valueOf(12.0f);\n f9615u = valueOf;\n f9616v = valueOf;\n }", "public interface C32458d<T> {\n /* renamed from: a */\n void mo83695a(T t);\n }", "@Test\n public void test_column_type_detection_double() throws SQLException {\n ColumnInfo info = testColumnTypeDetection(\"x\", NodeFactory.createLiteral(\"12.3e4\", XSDDatatype.XSDdouble), true, Types.DOUBLE, Double.class.getCanonicalName());\n Assert.assertEquals(16, info.getScale());\n Assert.assertEquals(16, info.getPrecision());\n Assert.assertTrue(info.isSigned());\n }", "public interface C10555f {\n /* renamed from: es */\n void mo22049es(boolean z);\n }", "public void method_873(double var1) {\n this.field_658 = var1;\n }", "public double[] getDoubleList();", "@Deprecated\r\n @Override\r\n public Double fromDouble(double value) {\r\n return value;\r\n }", "public interface C32459e<T> {\n /* renamed from: a */\n void mo83698a(T t);\n }", "public void method_891(double var1) {\n this.field_668 = var1;\n }", "public void get_TableValues(){\r\n\tFFM=99;\r\n\tADFM=99;\r\n\tDF=0;\r\n\tFLOAD=0;\r\n\t\r\n}", "double getFloatingPointField();", "public interface AbstractC10485b {\n /* renamed from: a */\n void mo64153a(boolean z);\n }", "@Override\n\t\t\tpublic ColumnMetaData getColumnMetaData() {\n\t\t\t\t\n\t\t\t\t\n\t\t\t\tthrow new UnsupportedOperationException(\n\t\t\t\t\t\t\"If you want to use val() to create a real\"\n\t\t\t\t\t\t\t\t+ \" column within a tuple, give it a name (i.e. use val(obj, name))!\");\n\t\t\t}", "public interface C32456b<T> {\n /* renamed from: a */\n void mo83696a(T t);\n }", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "public double getDouble(String name)\n/* */ {\n/* 1015 */ return getDouble(name, 0.0D);\n/* */ }", "private Data[] getFloats(double value, int npoints, int nattributes)\n\t{\n\t\tData[] data = new Data[npoints];\n\t\tfor (int i = 0; i < npoints; i++)\n\t\t\tdata[i] = nattributes == 1 ? new DataFloat((float) value)\n\t\t: new DataArrayOfFloats(new float[] { (float) value,\n\t\t\t\t(float) value });\n\t\t\treturn data;\n\t}", "public void mo1956a(dd ddVar) throws cf {\r\n this.f6478m.m10086a(this.f6479n);\r\n this.f6479n = (short) 0;\r\n }" ]
[ "0.5344452", "0.52673423", "0.5256152", "0.5168173", "0.5166196", "0.5145648", "0.51338506", "0.51196647", "0.51074445", "0.50538486", "0.49768347", "0.49735892", "0.49511394", "0.49470952", "0.49363813", "0.49234286", "0.49054694", "0.48951286", "0.48930085", "0.48717615", "0.4869534", "0.48551077", "0.4850218", "0.48417783", "0.48354855", "0.48325068", "0.48175135", "0.48087645", "0.47821411", "0.47800252", "0.477579", "0.47395515", "0.47386634", "0.47350717", "0.47231457", "0.4713435", "0.4712655", "0.47118318", "0.46962845", "0.4686771", "0.46821448", "0.46821368", "0.46798986", "0.4679661", "0.46764854", "0.46708244", "0.46618643", "0.46579146", "0.46373582", "0.46351898", "0.46348244", "0.46332103", "0.46324962", "0.46308866", "0.46268162", "0.462461", "0.46211308", "0.46186295", "0.4617639", "0.4613592", "0.46091264", "0.46067458", "0.46059027", "0.46049088", "0.46043375", "0.45997483", "0.45977002", "0.45909482", "0.4578829", "0.4577796", "0.45718306", "0.45685813", "0.45614988", "0.45552135", "0.45532048", "0.4551401", "0.45499504", "0.45469418", "0.45447648", "0.45428243", "0.4540477", "0.45356452", "0.45355672", "0.453049", "0.45292675", "0.45290026", "0.4526266", "0.45194957", "0.45191264", "0.4519111", "0.45157754", "0.45147586", "0.4510111", "0.45064628", "0.45044014", "0.4503501", "0.45034975", "0.45009658", "0.450076", "0.44959658", "0.44922578" ]
0.0
-1
$FF: renamed from: c (int, int, int, aji, int, int) void
public void method_2193(int var1, int var2, int var3, aji var4, int var5, int var6) { String[] var10000 = class_752.method_4253(); class_1033 var10001 = new class_1033; var10001.method_5846(var1, var2, var3, var4, var5, var6); class_1033 var8 = var10001; String[] var7 = var10000; Iterator var9 = this.field_1861[this.field_1862].iterator(); while(true) { if(!var9.hasNext()) { this.field_1861[this.field_1862].add(var8); break; } class_1033 var10 = (class_1033)var9.next(); if(var10.equals(var8)) { if(var7 != null) { return; } break; } } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "void mo5289a(C5102c c5102c);", "void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);", "public abstract void mo53562a(C18796a c18796a);", "void mo86a(C0163d c0163d);", "void mo5290b(C5102c c5102c);", "interface C30585a {\n /* renamed from: b */\n void mo27952b(C5379a c5379a, int i, C46650a c46650a, C7620bi c7620bi);\n }", "public abstract void mo70702a(C30989b c30989b);", "void mo17022c(int i);", "void mo7306c(int i, int i2);", "public abstract long c(int i2, int i3);", "public abstract void mo4381c(int i, int i2);", "void mo57278c();", "public abstract void mo9815c(int i, int i2);", "interface C1069a {\n /* renamed from: a */\n C1000w mo7300a(int i);\n\n /* renamed from: a */\n void mo7301a(int i, int i2);\n\n /* renamed from: a */\n void mo7302a(int i, int i2, Object obj);\n\n /* renamed from: a */\n void mo7303a(C1070b bVar);\n\n /* renamed from: b */\n void mo7304b(int i, int i2);\n\n /* renamed from: b */\n void mo7305b(C1070b bVar);\n\n /* renamed from: c */\n void mo7306c(int i, int i2);\n\n /* renamed from: d */\n void mo7308d(int i, int i2);\n }", "public interface C32231g {\n /* renamed from: a */\n void mo8280a(int i, int i2, C1207m c1207m);\n}", "C02(int i){\n\t\t\n\t}", "public void mo44231a(int i) {\n }", "void mo8712a(C9714a c9714a);", "public interface C0303q extends C0291e {\n /* renamed from: a */\n void mo1747a(int i);\n\n /* renamed from: a */\n void mo1749a(C0288c cVar);\n\n /* renamed from: a */\n void mo1751a(byte[] bArr);\n\n /* renamed from: b */\n void mo1753b(int i);\n\n /* renamed from: c */\n void mo1754c(int i);\n\n /* renamed from: d */\n void mo1755d(int i);\n\n /* renamed from: e */\n int mo1756e(int i);\n\n /* renamed from: g */\n int mo1760g();\n\n /* renamed from: g */\n void mo1761g(int i);\n\n /* renamed from: h */\n void mo1763h(int i);\n}", "public abstract int zzh(int i, int i2, int i3);", "public abstract int mo9736c(int i);", "void mo4873a(C4718l c4718l);", "void mo1754c(int i);", "public interface C0141g {\n /* renamed from: a */\n void mo84a();\n\n /* renamed from: a */\n void mo85a(int i);\n\n /* renamed from: a */\n void mo86a(C0163d c0163d);\n\n /* renamed from: a */\n void mo87a(String str);\n\n /* renamed from: a */\n void mo88a(byte[] bArr, int i, int i2);\n\n /* renamed from: b */\n C0139e mo89b();\n}", "void mo304a(C0366h c0366h);", "public abstract C14407a mo11609c(int i);", "void mo66998a(int i);", "public interface C8466a {\n /* renamed from: a */\n void mo25956a(int i);\n\n /* renamed from: a */\n void mo25957a(long j, long j2);\n }", "public static void c0() {\n\t}", "public abstract void mo9814c(int i);", "void mo12638c();", "public interface C2950c {\n /* renamed from: a */\n int mo9690a(int i, int i2);\n\n /* renamed from: a */\n int mo9691a(String str, String str2, float f);\n\n /* renamed from: a */\n int mo9692a(String[] strArr, int i);\n\n /* renamed from: a */\n void mo9693a();\n\n /* renamed from: a */\n void mo9694a(float f, float f2);\n\n /* renamed from: a */\n void mo9695a(float f, float f2, float f3, float f4, float f5);\n\n /* renamed from: a */\n void mo9696a(float f, float f2, int i);\n\n /* renamed from: a */\n void mo9697a(String str);\n\n /* renamed from: a */\n void mo9698a(String str, float f);\n\n /* renamed from: a */\n void mo9699a(String str, String str2, boolean z);\n\n /* renamed from: a */\n void mo9700a(String str, boolean z);\n\n /* renamed from: a */\n void mo9701a(boolean z);\n\n /* renamed from: b */\n int mo9702b(String str, String str2, float f);\n\n /* renamed from: b */\n void mo9703b(float f, float f2);\n\n /* renamed from: b */\n void mo9704b(float f, float f2, int i);\n\n /* renamed from: c */\n void mo9705c(float f, float f2);\n}", "void mo27576a(int i);", "public abstract void mo4377b(int i, int i2);", "public abstract void mo4386e(int i, int i2);", "public abstract void mo9800a(int i, int i2);", "public interface C3196it extends C3208jc {\n /* renamed from: a */\n void mo30275a(long j);\n\n /* renamed from: b */\n C3197iu mo30281b(long j);\n\n /* renamed from: b */\n boolean mo30282b();\n\n /* renamed from: c */\n byte mo30283c();\n\n /* renamed from: c */\n String mo30285c(long j);\n\n /* renamed from: d */\n void mo30290d(long j);\n\n /* renamed from: e */\n int mo30291e();\n\n /* renamed from: f */\n long mo30295f();\n}", "public abstract void mo9803a(int i, C3635j jVar);", "public final void mo91711c(int i) {\n super.mo91711c(i);\n }", "void mo80457c();", "public abstract void mo102900a(int i, int i2);", "interface C15937b {\n /* renamed from: a */\n void mo13368a();\n\n /* renamed from: a */\n void mo13369a(int i, int i2, int i3, boolean z);\n\n /* renamed from: a */\n void mo13370a(int i, int i2, List<C15929a> list) throws IOException;\n\n /* renamed from: a */\n void mo13371a(int i, long j);\n\n /* renamed from: a */\n void mo13372a(int i, ErrorCode errorCode);\n\n /* renamed from: a */\n void mo13373a(int i, ErrorCode errorCode, ByteString byteString);\n\n /* renamed from: a */\n void mo13374a(boolean z, int i, int i2);\n\n /* renamed from: a */\n void mo13375a(boolean z, int i, int i2, List<C15929a> list);\n\n /* renamed from: a */\n void mo13376a(boolean z, int i, BufferedSource bufferedSource, int i2) throws IOException;\n\n /* renamed from: a */\n void mo13377a(boolean z, C15943j c15943j);\n }", "void mo26876a(int i);", "void mo67924c();", "public abstract void mo9810b(int i, int i2);", "void mo8280a(int i, int i2, C1207m c1207m);", "public void mo5332a(int i) {\n }", "public abstract void mo9809b(int i);", "void mo66999a(int i, int i2);", "interface C0932a {\n /* renamed from: a */\n void mo7438a(int i, int i2);\n\n /* renamed from: b */\n void mo7439b(C0933b bVar);\n\n /* renamed from: c */\n void mo7440c(int i, int i2, Object obj);\n\n /* renamed from: d */\n void mo7441d(C0933b bVar);\n\n /* renamed from: e */\n RecyclerView.ViewHolder mo7442e(int i);\n\n /* renamed from: f */\n void mo7443f(int i, int i2);\n\n /* renamed from: g */\n void mo7444g(int i, int i2);\n\n /* renamed from: h */\n void mo7445h(int i, int i2);\n }", "public abstract void mo4378b(int i, zzud zzud);", "public interface C4740t {\n /* renamed from: a */\n void mo25261a(Context context);\n\n /* renamed from: a */\n boolean mo25262a(int i);\n\n /* renamed from: a */\n boolean mo25263a(String str, String str2, boolean z, int i, int i2, int i3, boolean z2, C4619b bVar, boolean z3);\n\n /* renamed from: b */\n byte mo25264b(int i);\n\n /* renamed from: c */\n boolean mo25265c();\n\n /* renamed from: c */\n boolean mo25266c(int i);\n}", "void mo122221a(int i);", "public abstract void mo9733a(int i);", "void mo63039b(int i, int i2);", "public abstract void mo4364a(int i, zzud zzud);", "void mo1494c(int i);", "void mo12647a(C3333i iVar);", "interface C9349bs {\n /* renamed from: a */\n int mo28885a(int i);\n\n /* renamed from: a */\n void mo28886a(int i, double d) throws zzlm;\n\n /* renamed from: a */\n void mo28887a(int i, int i2, zzno zzno) throws IOException, InterruptedException;\n\n /* renamed from: a */\n void mo28888a(int i, long j, long j2) throws zzlm;\n\n /* renamed from: a */\n void mo28889a(int i, String str) throws zzlm;\n\n /* renamed from: b */\n void mo28890b(int i) throws zzlm;\n\n /* renamed from: b */\n void mo28891b(int i, long j) throws zzlm;\n\n /* renamed from: c */\n boolean mo28892c(int i);\n}", "interface C0312e {\n /* renamed from: a */\n void mo4671a(View view, int i, int i2, int i3, int i4);\n }", "void m15860a(int i, int i2, int i3);", "public abstract int mo4307b(int i);", "void mo7304b(int i, int i2);", "public interface C1423a {\n /* renamed from: a */\n void mo6888a(int i);\n }", "void mo28717a(zzc zzc);", "public interface C9326f extends C8877c<C9330i, C9331j, C9327g> {\n /* renamed from: a */\n void mo24142a(long j);\n}", "public abstract int c();", "public abstract int c();", "void mo4874b(C4718l c4718l);", "abstract void mo4366a(int i, zzwt zzwt, cu cuVar);", "void mo7301a(int i, int i2);", "void mo63037a(int i, int i2);", "void mo88773a(int i);", "void mo17009a(int i, int i2, int i3);", "public interface C39684b {\n /* renamed from: a */\n void mo98969a();\n\n /* renamed from: a */\n void mo98970a(C29296g gVar);\n\n /* renamed from: a */\n void mo98971a(C29296g gVar, int i);\n }", "void mo28306a();", "void mo41083a();", "void mo1933b(int i);", "void mo4102a(int i, int i2);", "void mo21072c();", "public abstract void mo27385c();", "void mo72114c();", "public interface C3598a {\n /* renamed from: a */\n void mo11024a(int i, int i2, String str);\n }", "void mo54407a(int i, int i2);", "void mo17012c();", "private static void cajas() {\n\t\t\n\t}", "void mo18324a(C7260j jVar);", "void mo88524c();", "public interface C43270a {\n /* renamed from: a */\n void mo64942a(String str, long j, long j2);\n}", "void mo54406a(int i);", "void m15858a(int i);", "void mo4103b(int i, int i2);", "public void mo3350a(int i) {\n }", "void mo6888a(int i);", "void mo34684de(int i, int i2);", "public interface C13373b {\n /* renamed from: a */\n void mo32681a(String str, int i, boolean z);\n}", "private void b(int paramInt)\r\n/* 193: */ {\r\n/* 194:203 */ this.h.a(a(paramInt));\r\n/* 195: */ }", "public abstract void mo4382c(int i, long j);", "public abstract int zzg(int i, int i2, int i3);", "void mo1753b(int i);", "void mo17021c();" ]
[ "0.71309566", "0.7125437", "0.70581025", "0.7041523", "0.70374113", "0.6961895", "0.6948118", "0.6921856", "0.6911101", "0.6904822", "0.6831658", "0.68291396", "0.6799824", "0.67524385", "0.67344266", "0.6716527", "0.67088044", "0.6704212", "0.6703395", "0.66993964", "0.6684613", "0.6677904", "0.667508", "0.6674985", "0.66725683", "0.6672527", "0.6653924", "0.6653128", "0.66390395", "0.6632053", "0.6631869", "0.6626456", "0.66260386", "0.6623573", "0.6622217", "0.66202873", "0.6618414", "0.66176033", "0.6616841", "0.6612226", "0.6608471", "0.6606879", "0.66039157", "0.6598246", "0.6594025", "0.6589859", "0.6589368", "0.65799713", "0.65790486", "0.65753293", "0.6572469", "0.65685505", "0.6567746", "0.65614176", "0.6559848", "0.65558934", "0.65545136", "0.65531003", "0.65519893", "0.65499425", "0.65491986", "0.6534812", "0.6534496", "0.6533899", "0.65313965", "0.6530106", "0.6519843", "0.6519843", "0.6518298", "0.6517291", "0.6515927", "0.6513174", "0.65131253", "0.65127814", "0.65109485", "0.6510802", "0.6510363", "0.6508368", "0.65079176", "0.6501837", "0.6500868", "0.64992243", "0.6495179", "0.6487945", "0.64862365", "0.6485613", "0.64847356", "0.6480277", "0.6476138", "0.64740986", "0.6471068", "0.6470806", "0.6470695", "0.64685863", "0.6454935", "0.6453407", "0.6449171", "0.6441428", "0.644142", "0.6441078", "0.64333606" ]
0.0
-1
$FF: renamed from: r () void
private void method_2252() { String[] var1 = class_752.method_4253(); do { boolean var10000 = this.field_1861[this.field_1862].isEmpty(); int var2; label45: while(true) { if(var10000) { return; } var2 = this.field_1862; this.field_1862 ^= 1; Iterator var3 = this.field_1861[var2].iterator(); while(true) { if(!var3.hasNext()) { break label45; } class_1033 var4 = (class_1033)var3.next(); label40: { class_354 var6; label55: { try { var6 = this; if(var1 == null) { break label55; } var10000 = this.method_2253(var4); if(var1 == null) { break; } } catch (IllegalStateException var5) { throw method_2260(var5); } if(!var10000) { break label40; } var6 = this; } class_1627 var7 = var6.field_1850.method_2383(); double var10001 = (double)var4.method_5847(); double var10002 = (double)var4.method_5848(); double var10003 = (double)var4.method_5849(); int var10005 = this.field_1820.field_5738; class_297 var10006 = new class_297; var10006.method_1699(var4.method_5847(), var4.method_5848(), var4.method_5849(), var4.method_5852(), var4.method_5850(), var4.method_5851()); var7.method_8903(var10001, var10002, var10003, 64.0D, var10005, var10006); } if(var1 == null) { break label45; } } } this.field_1861[var2].clear(); } while(var1 != null); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "@Override\n\tpublic void r() {\n\n\t}", "public void mo21793R() {\n }", "void mo57277b();", "void mo80455b();", "final /* synthetic */ void m65927a(Void voidR) {\n this.f56359a.m56689p();\n }", "void mo3194r();", "public void mo130018a(R r) {\n this.f109118j = r;\n this.f109119k = 2;\n mo130020b();\n }", "public abstract void mo42331g();", "public int R(){\r\n return R;\r\n }", "public void mo3376r() {\n }", "public final void b() {\n /*\n r10 = this;\n r0 = 0\n java.lang.Object[] r1 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r3 = f53248e\n java.lang.Class[] r6 = new java.lang.Class[r0]\n java.lang.Class r7 = java.lang.Void.TYPE\n r4 = 0\n r5 = 55479(0xd8b7, float:7.7743E-41)\n r2 = r10\n boolean r1 = com.meituan.robust.PatchProxy.isSupport(r1, r2, r3, r4, r5, r6, r7)\n if (r1 == 0) goto L_0x0025\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = f53248e\n r5 = 0\n r6 = 55479(0xd8b7, float:7.7743E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r10\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x0025:\n com.ss.android.ugc.aweme.live.alphaplayer.e$i r9 = r10.h\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r5 = 0\n r6 = 55516(0xd8dc, float:7.7794E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n boolean r2 = com.meituan.robust.PatchProxy.isSupport(r2, r3, r4, r5, r6, r7, r8)\n if (r2 == 0) goto L_0x004b\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = com.ss.android.ugc.aweme.live.alphaplayer.e.i.f53268a\n r5 = 0\n r6 = 55516(0xd8dc, float:7.7794E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x004b:\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r2 = g\n monitor-enter(r2)\n r0 = 1\n r9.f53270c = r0 // Catch:{ all -> 0x006e }\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = g // Catch:{ all -> 0x006e }\n r0.notifyAll() // Catch:{ all -> 0x006e }\n L_0x0056:\n boolean r0 = r9.f53269b // Catch:{ all -> 0x006e }\n if (r0 != 0) goto L_0x006c\n boolean r0 = r9.f53271d // Catch:{ all -> 0x006e }\n if (r0 != 0) goto L_0x006c\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = g // Catch:{ InterruptedException -> 0x0064 }\n r0.wait() // Catch:{ InterruptedException -> 0x0064 }\n goto L_0x0056\n L_0x0064:\n java.lang.Thread r0 = java.lang.Thread.currentThread() // Catch:{ all -> 0x006e }\n r0.interrupt() // Catch:{ all -> 0x006e }\n goto L_0x0056\n L_0x006c:\n monitor-exit(r2) // Catch:{ all -> 0x006e }\n return\n L_0x006e:\n r0 = move-exception\n monitor-exit(r2) // Catch:{ all -> 0x006e }\n throw r0\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.b():void\");\n }", "public abstract void mo70713b();", "public abstract void mo42329d();", "void mo41086b();", "public abstract int mo9753r();", "public abstract void mo27386d();", "void mo119582b();", "void mo28194a();", "void mo72113b();", "private final void m14217c(R r) {\n this.f11870i = r;\n this.f11875n = null;\n this.f11866e.countDown();\n this.f11871j = this.f11870i.getStatus();\n if (this.f11873l) {\n this.f11868g = null;\n } else if (this.f11868g != null) {\n this.f11864b.removeMessages(2);\n this.f11864b.m8915a(this.f11868g, mo3575g());\n } else if (this.f11870i instanceof Releasable) {\n this.mResultGuardian = new C2474b();\n }\n ArrayList arrayList = this.f11867f;\n int size = arrayList.size();\n int i = 0;\n while (i < size) {\n Object obj = arrayList.get(i);\n i++;\n ((zza) obj).zzr(this.f11871j);\n }\n this.f11867f.clear();\n }", "public abstract void mo6549b();", "public abstract void mo42330e();", "void mo67923b();", "void mo41083a();", "public abstract void mo35054b();", "public abstract void mo957b();", "void mo80457c();", "public final void b() {\n /*\n r9 = this;\n r0 = 0\n java.lang.Object[] r1 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r3 = f53268a\n java.lang.Class[] r6 = new java.lang.Class[r0]\n java.lang.Class r7 = java.lang.Void.TYPE\n r4 = 0\n r5 = 55519(0xd8df, float:7.7799E-41)\n r2 = r9\n boolean r1 = com.meituan.robust.PatchProxy.isSupport(r1, r2, r3, r4, r5, r6, r7)\n if (r1 == 0) goto L_0x0025\n java.lang.Object[] r2 = new java.lang.Object[r0]\n com.meituan.robust.ChangeQuickRedirect r4 = f53268a\n r5 = 0\n r6 = 55519(0xd8df, float:7.7799E-41)\n java.lang.Class[] r7 = new java.lang.Class[r0]\n java.lang.Class r8 = java.lang.Void.TYPE\n r3 = r9\n com.meituan.robust.PatchProxy.accessDispatch(r2, r3, r4, r5, r6, r7, r8)\n return\n L_0x0025:\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r0 = com.ss.android.ugc.aweme.live.alphaplayer.e.g\n monitor-enter(r0)\n r1 = 1\n r9.h = r1 // Catch:{ all -> 0x0044 }\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = com.ss.android.ugc.aweme.live.alphaplayer.e.g // Catch:{ all -> 0x0044 }\n r1.notifyAll() // Catch:{ all -> 0x0044 }\n L_0x0030:\n boolean r1 = r9.f53269b // Catch:{ all -> 0x0044 }\n if (r1 != 0) goto L_0x0042\n com.ss.android.ugc.aweme.live.alphaplayer.e$j r1 = com.ss.android.ugc.aweme.live.alphaplayer.e.g // Catch:{ InterruptedException -> 0x003a }\n r1.wait() // Catch:{ InterruptedException -> 0x003a }\n goto L_0x0030\n L_0x003a:\n java.lang.Thread r1 = java.lang.Thread.currentThread() // Catch:{ all -> 0x0044 }\n r1.interrupt() // Catch:{ all -> 0x0044 }\n goto L_0x0030\n L_0x0042:\n monitor-exit(r0) // Catch:{ all -> 0x0044 }\n return\n L_0x0044:\n r1 = move-exception\n monitor-exit(r0) // Catch:{ all -> 0x0044 }\n throw r1\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.i.b():void\");\n }", "public abstract void mo45765b();", "public interface C11922a {\n void bvR();\n }", "void mo60893b();", "public void mo6944a() {\n }", "public abstract void mo27385c();", "void mo54405a();", "void mo80452a();", "void mo84655a();", "public void func_70305_f() {}", "@Override // g.b.f.i.m\n /* Code decompiled incorrectly, please refer to instructions dump. */\n public boolean i(g.b.f.i.r r10) {\n /*\n // Method dump skipped, instructions count: 121\n */\n throw new UnsupportedOperationException(\"Method not decompiled: g.b.f.i.q.i(g.b.f.i.r):boolean\");\n }", "void mo28306a();", "void mo9693a();", "public abstract void mo56925d();", "public abstract void m15813a();", "public void mo115190b() {\n }", "public abstract void mo27464a();", "private S(com.google.ad r9, com.google.h r10) {\n /*\n r8 = this;\n r0 = 0;\n r1 = -1;\n r7 = 2;\n r2 = 1;\n r5 = org.whispersystems.Y.r;\n r8.<init>();\n r8.k = r1;\n r8.n = r1;\n r8.c();\n r6 = com.google.eV.g();\n r1 = r0;\n L_0x0015:\n if (r0 != 0) goto L_0x006f;\n L_0x0017:\n r3 = r9.z();\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n switch(r3) {\n case 0: goto L_0x0085;\n case 10: goto L_0x00c6;\n case 18: goto L_0x0055;\n default: goto L_0x001e;\n };\n L_0x001e:\n r3 = r8.a(r9, r6, r10, r3);\t Catch:{ fN -> 0x0089, IOException -> 0x00aa }\n if (r3 != 0) goto L_0x006d;\n L_0x0024:\n if (r5 == 0) goto L_0x00c4;\n L_0x0026:\n r3 = r2;\n L_0x0027:\n r0 = 0;\n r4 = r8.h;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r4 = r4 & 1;\n if (r4 != r2) goto L_0x00c1;\n L_0x002e:\n r0 = r8.f;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r0 = r0.w();\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r4 = r0;\n L_0x0035:\n r0 = org.whispersystems.Y.o;\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r0 = r9.a(r0, r10);\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r0 = (org.whispersystems.Y) r0;\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r8.f = r0;\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n if (r4 == 0) goto L_0x004c;\n L_0x0041:\n r0 = r8.f;\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r4.a(r0);\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r0 = r4.a();\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n r8.f = r0;\t Catch:{ fN -> 0x00a8, IOException -> 0x00aa }\n L_0x004c:\n r0 = r8.h;\t Catch:{ fN -> 0x00b9, IOException -> 0x00aa }\n r0 = r0 | 1;\n r8.h = r0;\t Catch:{ fN -> 0x00b9, IOException -> 0x00aa }\n if (r5 == 0) goto L_0x00bf;\n L_0x0054:\n r0 = r3;\n L_0x0055:\n r3 = r1 & 2;\n if (r3 == r7) goto L_0x0062;\n L_0x0059:\n r3 = new java.util.ArrayList;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r3.<init>();\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r8.l = r3;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r1 = r1 | 2;\n L_0x0062:\n r3 = r8.l;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r4 = org.whispersystems.Y.o;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r4 = r9.a(r4, r10);\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n r3.add(r4);\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n L_0x006d:\n if (r5 == 0) goto L_0x0015;\n L_0x006f:\n r0 = r1 & 2;\n if (r0 != r7) goto L_0x007b;\n L_0x0073:\n r0 = r8.l;\t Catch:{ fN -> 0x00bb }\n r0 = java.util.Collections.unmodifiableList(r0);\t Catch:{ fN -> 0x00bb }\n r8.l = r0;\t Catch:{ fN -> 0x00bb }\n L_0x007b:\n r0 = r6.d();\n r8.e = r0;\n r8.b();\n return;\n L_0x0085:\n if (r5 == 0) goto L_0x00c4;\n L_0x0087:\n r0 = r2;\n goto L_0x001e;\n L_0x0089:\n r0 = move-exception;\n throw r0;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n L_0x008b:\n r0 = move-exception;\n r0 = r0.a(r8);\t Catch:{ all -> 0x0091 }\n throw r0;\t Catch:{ all -> 0x0091 }\n L_0x0091:\n r0 = move-exception;\n r1 = r1 & 2;\n if (r1 != r7) goto L_0x009e;\n L_0x0096:\n r1 = r8.l;\t Catch:{ fN -> 0x00bd }\n r1 = java.util.Collections.unmodifiableList(r1);\t Catch:{ fN -> 0x00bd }\n r8.l = r1;\t Catch:{ fN -> 0x00bd }\n L_0x009e:\n r1 = r6.d();\n r8.e = r1;\n r8.b();\n throw r0;\n L_0x00a8:\n r0 = move-exception;\n throw r0;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n L_0x00aa:\n r0 = move-exception;\n r2 = new com.google.fN;\t Catch:{ all -> 0x0091 }\n r0 = r0.getMessage();\t Catch:{ all -> 0x0091 }\n r2.<init>(r0);\t Catch:{ all -> 0x0091 }\n r0 = r2.a(r8);\t Catch:{ all -> 0x0091 }\n throw r0;\t Catch:{ all -> 0x0091 }\n L_0x00b9:\n r0 = move-exception;\n throw r0;\t Catch:{ fN -> 0x008b, IOException -> 0x00aa }\n L_0x00bb:\n r0 = move-exception;\n throw r0;\n L_0x00bd:\n r0 = move-exception;\n throw r0;\n L_0x00bf:\n r0 = r3;\n goto L_0x006d;\n L_0x00c1:\n r4 = r0;\n goto L_0x0035;\n L_0x00c4:\n r0 = r2;\n goto L_0x006d;\n L_0x00c6:\n r3 = r0;\n goto L_0x0027;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: org.whispersystems.S.<init>(com.google.ad, com.google.h):void\");\n }", "void mo21073d();", "public abstract void mo102899a();", "public abstract void mo3994a();", "public abstract void mo30696a();", "public void mo97908d() {\n }", "void mo54435d();", "public abstract int mo9741f();", "public void t();", "public void mo9137b() {\n }", "private final void i() {\n }", "public abstract void mo4359a();", "public abstract Object mo26777y();", "public abstract int mo9747l();", "public abstract int mo12582RV(int i);", "void mo57278c();", "public abstract int mo41077c();", "@Override\n public void func_104112_b() {\n \n }", "public void rec() {\n\n\t}", "void mo22249a();", "public void mo21779D() {\n }", "public abstract int mo12578RR(int i);", "public n(boolean r10) {\n /*\n r8 = this;\n com.ss.android.ugc.aweme.live.alphaplayer.e.this = r9\n if (r10 == 0) goto L_0x0009\n r10 = 16\n r6 = 16\n goto L_0x000b\n L_0x0009:\n r10 = 0\n r6 = 0\n L_0x000b:\n r7 = 0\n r2 = 8\n r3 = 8\n r4 = 8\n r5 = 0\n r0 = r8\n r1 = r9\n r0.<init>(r2, r3, r4, r5, r6, r7)\n return\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.ss.android.ugc.aweme.live.alphaplayer.e.n.<init>(com.ss.android.ugc.aweme.live.alphaplayer.e, boolean):void\");\n }", "void mo72111a();", "void mo88523b();", "void m1864a() {\r\n }", "public abstract int mo123247f();", "public void mo21781F() {\n }", "void mo98969a();", "void mo105476a();", "public void furyo ()\t{\n }", "public abstract int mo4375b();", "public void mo32111rr(int i) {\n }", "void mo71b();", "public abstract int mo12579RS(int i);", "public void mo21825b() {\n }", "void mo119581a();", "void mo60892a();", "void mo56163g();", "void mo310e();", "public abstract int mo12572RL(int i);", "void mo37810a();", "public void m23075a() {\n }", "void mo7353b();", "void mo57275a();", "public org.a9 a() {\n /*\n r4 = this;\n r1 = 0;\n r0 = r4.c;\n if (r0 != 0) goto L_0x0040;\n L_0x0005:\n monitor-enter(r4);\n r0 = r4.c;\t Catch:{ all -> 0x0043 }\n if (r0 != 0) goto L_0x003f;\n L_0x000a:\n r2 = r4.e;\t Catch:{ IllegalArgumentException -> 0x0041 }\n if (r2 != 0) goto L_0x003f;\n L_0x000e:\n r0 = r4.b;\t Catch:{ all -> 0x0043 }\n r2 = z;\t Catch:{ all -> 0x0043 }\n r3 = 8;\n r2 = r2[r3];\t Catch:{ all -> 0x0043 }\n r3 = 0;\n r0 = r0.getSharedPreferences(r2, r3);\t Catch:{ all -> 0x0043 }\n r2 = z;\t Catch:{ all -> 0x0043 }\n r3 = 6;\n r2 = r2[r3];\t Catch:{ all -> 0x0043 }\n r3 = \"\";\n r0 = r0.getString(r2, r3);\t Catch:{ all -> 0x0043 }\n r2 = android.text.TextUtils.isEmpty(r0);\t Catch:{ IllegalArgumentException -> 0x0046 }\n if (r2 == 0) goto L_0x0053;\n L_0x002d:\n r2 = r1;\n L_0x002e:\n if (r2 == 0) goto L_0x0039;\n L_0x0030:\n r0 = new org.a9;\t Catch:{ IllegalArgumentException -> 0x0048 }\n r0.<init>(r2);\t Catch:{ IllegalArgumentException -> 0x0048 }\n r2 = com.whatsapp.DialogToastActivity.f;\t Catch:{ IllegalArgumentException -> 0x0048 }\n if (r2 == 0) goto L_0x003a;\n L_0x0039:\n r0 = r1;\n L_0x003a:\n r4.c = r0;\t Catch:{ all -> 0x0043 }\n r1 = 1;\n r4.e = r1;\t Catch:{ all -> 0x0043 }\n L_0x003f:\n monitor-exit(r4);\t Catch:{ all -> 0x0043 }\n L_0x0040:\n return r0;\n L_0x0041:\n r0 = move-exception;\n throw r0;\t Catch:{ all -> 0x0043 }\n L_0x0043:\n r0 = move-exception;\n monitor-exit(r4);\t Catch:{ all -> 0x0043 }\n throw r0;\n L_0x0046:\n r0 = move-exception;\n throw r0;\t Catch:{ IllegalArgumentException -> 0x0048 }\n L_0x0048:\n r0 = move-exception;\n r2 = z;\t Catch:{ all -> 0x0043 }\n r3 = 7;\n r2 = r2[r3];\t Catch:{ all -> 0x0043 }\n com.whatsapp.util.Log.c(r2, r0);\t Catch:{ all -> 0x0043 }\n r0 = r1;\n goto L_0x003a;\n L_0x0053:\n r2 = 3;\n r0 = android.backport.util.Base64.decode(r0, r2);\t Catch:{ IllegalArgumentException -> 0x0048 }\n r2 = r0;\n goto L_0x002e;\n */\n throw new UnsupportedOperationException(\"Method not decompiled: com.whatsapp.l9.a():org.a9\");\n }", "void mo67920a();", "public final void mo91715d() {\n }", "public abstract int mo9742g();", "int getR();", "void mo3193f();", "void mo54440f();", "void mo21074e();", "public void mo21787L() {\n }", "@Override\n\t\t\t\tpublic void a() {\n\n\t\t\t\t}", "void mo67924c();", "void mo88521a();" ]
[ "0.77524906", "0.6965824", "0.6798352", "0.6751611", "0.6692003", "0.6675355", "0.6642572", "0.66363084", "0.6599307", "0.65971035", "0.6597011", "0.6593468", "0.659239", "0.6588144", "0.654346", "0.65340996", "0.6530299", "0.6494323", "0.64930916", "0.6485749", "0.64715356", "0.6460532", "0.64519125", "0.6450807", "0.6450552", "0.6421731", "0.63960207", "0.6391271", "0.63910776", "0.63812095", "0.6378077", "0.63730276", "0.637269", "0.636687", "0.63648045", "0.6364123", "0.63514686", "0.6345997", "0.6334799", "0.6330893", "0.63293403", "0.6324453", "0.6324268", "0.6322011", "0.63152397", "0.6311892", "0.6310674", "0.6310494", "0.63083196", "0.6306612", "0.63047343", "0.63005733", "0.6298112", "0.6295118", "0.6293606", "0.6288365", "0.6288151", "0.6286892", "0.6284487", "0.6278259", "0.6272403", "0.62677455", "0.6266658", "0.62661815", "0.6264444", "0.6257594", "0.6254789", "0.625388", "0.62532413", "0.62406474", "0.6235613", "0.6231296", "0.6228398", "0.62253326", "0.62239134", "0.6222526", "0.6215047", "0.6210463", "0.6206786", "0.6201995", "0.6200287", "0.6199682", "0.61983436", "0.6195464", "0.6194799", "0.6193114", "0.618942", "0.61862415", "0.6185109", "0.6180215", "0.61756647", "0.6171363", "0.6168053", "0.6144438", "0.61302626", "0.6127994", "0.6124451", "0.6123112", "0.61169493", "0.61123925", "0.6112285" ]
0.0
-1