Diff
stringlengths
5
2k
FaultInducingLabel
int64
0
1
AccumuloOutputFormat.setOutputInfo(job.getConfiguration(), args[0], args[1].getBytes(), true, args[5]); AccumuloOutputFormat.setZooKeeperInstance(job.getConfiguration(), args[3], args[4]);
0
* Copyright 2005-2011 The Apache Software Foundation. private final List<XMLStructure> content; public DOMSignatureProperty(List<XMLStructure> content, String target, String id) { List<XMLStructure> contentCopy = new ArrayList<XMLStructure>(content); List<XMLStructure> content = new ArrayList<XMLStructure>(length); throws MarshalException { Element propElem = DOMUtils.createElement(ownerDoc, "SignatureProperty", XMLSignature.XMLNS, dsPrefix); for (XMLStructure property : content) { DOMUtils.appendChild(propElem, ((javax.xml.crypto.dom.DOMStructure)property).getNode()); @Override SignatureProperty osp = (SignatureProperty)o; boolean idsEqual = (id == null ? osp.getId() == null : id.equals(osp.getId())); @SuppressWarnings("unchecked") List<XMLStructure> ospContent = osp.getContent(); return (equalsContent(ospContent) && target.equals(osp.getTarget()) && idsEqual); private boolean equalsContent(List<XMLStructure> otherContent) { XMLStructure oxs = otherContent.get(i); XMLStructure xs = content.get(i); Node onode = ((javax.xml.crypto.dom.DOMStructure)oxs).getNode(); Node node = ((javax.xml.crypto.dom.DOMStructure)xs).getNode();
0
super(org.apache.commons.bcel6.Const.BREAKPOINT, (short) 1);
0
@SuppressWarnings("unused")
0
Copyright 2001,2003 The Apache Software Foundation Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License. */
0
* Copyright 2002-2005 The Apache Software Foundation.
0
waitFor(80000, new Predicate() {
0
* @version $Revision$
0
List<Predicate> predicateList = new LinkedList<>();
1
public class Class2HTML { String str = constant_pool.getConstantString(index, Constants.CONSTANT_Class);
0
private static final GarbageCollectorStatus EMPTY = new GarbageCollectorStatus(); public static GarbageCollectorStatus getEmpty() { return EMPTY; }
0
import static org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument; import static org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkNotNull; import org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.Collections2; import org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.Ordering; import org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.SortedSetMultimap; import org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.TreeMultimap;
0
/* * Copyright 1999-2004 The Apache Software Foundation. * * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.cocoon.woody.datatype.convertor; import java.util.Locale; import java.util.Date; /** * A Convertor for Date objects which uses the number of milliseconds since * January 1, 1970, 00:00:00 GMT as string representation. * * @version CVS $Id: MillisDateConvertor.java,v 1.5 2004/03/09 13:54:15 reinhard Exp $ */ public class MillisDateConvertor implements Convertor { public Object convertFromString(String value, Locale locale, Convertor.FormatCache formatCache) { try { long date = Long.parseLong(value); return new Date(date); } catch (NumberFormatException e) { return null; } } public String convertToString(Object value, Locale locale, Convertor.FormatCache formatCache) { Date date = (Date)value; return String.valueOf(date.getTime()); } public Class getTypeClass() { return Date.class; } }
0
import org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode; void handleEmpty(PTransformNode transform);
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
import java.util.*; synchronized ( this.events ) this.events.add(event); if ( events.size() > this.maxSize ) { events.remove(1); } List copiedEvents; synchronized ( this.events ) copiedEvents = new ArrayList(this.events); } int index = 0; final Iterator i = copiedEvents.iterator(); while ( i.hasNext() ) { eventJson( jw, (Event)i.next(), index ); index++; if ( names != null && names.length > 0 ) { for(int i=0;i<names.length;i++) {
0
* Copyright 2001-2006 The Apache Software Foundation
0
* <p> or:
0
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jelly/src/java/org/apache/commons/jelly/TagSupport.java,v 1.27 2003/10/09 21:21:27 rdonkin Exp $ * $Revision: 1.27 $ * $Date: 2003/10/09 21:21:27 $ * any, must include the following acknowledgement: * Alternately, this acknowledgement may appear in the software itself, * if and wherever such third-party acknowledgements normally appear. * permission of the Apache Software Foundation. * $Id: TagSupport.java,v 1.27 2003/10/09 21:21:27 rdonkin Exp $ * @version $Revision: 1.27 $
0
import org.bouncycastle.asn1.x509.Extension; certGen.addExtension(Extension.subjectKeyIdentifier, false, extensionUtils.createSubjectKeyIdentifier(kp.getPublic())); certGen.addExtension(Extension.basicConstraints, false, new BasicConstraints(isCertAuthority)); certGen.addExtension(Extension.authorityKeyIdentifier, false, extensionUtils.createAuthorityKeyIdentifier(signerPublicKey)); certGen.addExtension(Extension.keyUsage, true, new KeyUsage(KeyUsage.keyCertSign));
0
* @author <a href="mailto:[email protected]">Felix Project Team</a>
0
import org.apache.accumulo.core.security.thrift.ThriftInstanceTokenWrapper; import org.apache.accumulo.core.security.tokens.InstanceTokenWrapper; private InstanceTokenWrapper credentials; public void init(FileSystem fs, Instance instance, InstanceTokenWrapper credentials, boolean noTrash) throws IOException { public GCStatus getStatus(TInfo info, ThriftInstanceTokenWrapper credentials) {
0
static Enumeration convertToLocalUrls(Enumeration urls) { return new ToLocalUrlEnumeration(urls); } static URL convertToLocalUrl(URL url) { if (url.getProtocol().equals("bundle")) { try { url = ((URLHandlersBundleURLConnection) url.openConnection()).getLocalURL(); } catch (IOException ex) { // Ignore and add original url. } } return url; } static class ToLocalUrlEnumeration implements Enumeration { final Enumeration enumeration; ToLocalUrlEnumeration(Enumeration enumeration) { this.enumeration = enumeration; } public boolean hasMoreElements() { return enumeration.hasMoreElements(); } public Object nextElement() { URL url = (URL) enumeration.nextElement(); return convertToLocalUrl(url); } } urls = convertToLocalUrls(urls); return ModuleImpl.this.getResourcesLocal(name); url = convertToLocalUrl(url); public Enumeration getResources(String name) throws IOException { Enumeration urls = super.getResources(name); if (m_useLocalURLs) { urls = convertToLocalUrls(urls); } return urls; } return ModuleImpl.this.getResourceLocal(name); return ModuleImpl.this.getResourcesByDelegation(name);
0
import org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo;
0
StreamingApplication app = (dag, conf) -> dag.setAttribute(DAGContext.APPLICATION_NAME, "DummyApp");
0
pranges.add(new PRange(null, false, stop, false)); String cookie = tpc.proxy().createScanner(userpass, testtable, null, null, new PRange(null, false, stop, false));
0
package org.apache.batik.ext.awt.image.renderable; public class AffineRable8Bit extends AbstractRable public AffineRable8Bit(Filter src, AffineTransform affine) {
0
* values, each of which is of the form {@code key=value}. These
0
import org.slf4j.Logger; import org.slf4j.LoggerFactory; private static final Logger LOG = LoggerFactory.getLogger(SlaModule.class); LOG.debug("Scheduled SLA calculation with {} msec interval.", interval);
0
import org.apache.beam.sdk.schemas.Schema.TypeName; TypeName type = field.getType().getTypeName(); || (rawObj instanceof BigDecimal && type != TypeName.DECIMAL)) {
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
import org.apache.accumulo.server.ServerUtil;
0
/** * Construct a LessEqualsPredicate. * * @param propertyId the property id * @param value the value * * @throws IllegalArgumentException if the given value is null */ if (value == null) { throw new IllegalArgumentException("Value can't be null."); }
0
* @author <a href="mailto:[email protected]">Felix Project Team</a>
0
* Copyright 2001-2004 The Apache Software Foundation. * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License.
0
* @param hdfsApi hdfs api public FilePaginator(String filePath, HdfsApi hdfsApi) { this.hdfsApi = hdfsApi;
0
* This class is immutable and thread-safe. *
0
import org.apache.hc.core5.http.impl.ConnectionListener;
0
if (Charset.forName(csName).canEncode() && ! "COMPOUND_TEXT".equalsIgnoreCase(csName) && ! "x-COMPOUND_TEXT".equalsIgnoreCase(csName)) {
0
final List<FileInfo> queueExpected = new ArrayList<FileInfo>(); final List<FileObject> queueActual = new ArrayList<FileObject>(); final FileObject file = queueActual.remove(0); final FileInfo info = queueExpected.remove(0); final FileInfo childInfo = info.children.get(childName); final List<FileObject> expectedFiles = selector.finish(); final FileObject expected = expectedFiles.get(i);
0
Response response2 = fileBrowserService.download().browse("/tmp/testUpload.tmp", false, false, httpHeaders, uriInfo);
0
assertNotNull(bean); // just to prevent compiler warning on unused var
0
"The %s service is currently installed on the cluster. " + "This service is removed from the new release and must be removed before the upgrade can continue.") .put(ServicePresenceCheck.KEY_SERVICE_REPLACED, "After upgrading, %s can be installed as the replacement.").build());
0
import java.util.HashMap; import java.util.HashSet; import java.util.Map; import java.util.Set;
0
/* package org.apache.felix.bundlerepository; public interface Property String VERSION = "version"; String URL = "url"; String URI = "uri"; String LONG = "long"; String DOUBLE = "double"; String SET = "set"; String getName(); String getType(); String getValue(); Object getConvertedValue(); }
0
return resourceProviderFactory.getUserResourceProvider(managementController); case UserAuthenticationSource: return resourceProviderFactory.getUserAuthenticationSourceResourceProvider();
0
* Whether this source should allow dynamic splitting of the offset ranges. * * <p>True by default. Override this to return false if the source cannot * support dynamic splitting correctly. If this returns false, * {@link OffsetBasedSource.OffsetBasedReader#splitAtFraction} will refuse all split requests. */ public boolean allowsDynamicSplitting() { return true; } /** if (!getCurrentSource().allowsDynamicSplitting()) { return null; }
0
import static org.apache.aurora.gen.CronCollisionPolicy.KILL_EXISTING; .setCronCollisionPolicy(KILL_EXISTING)
0
import java.util.Set; import com.twitter.mesos.gen.TwitterTaskInfo; import com.twitter.mesos.gen.storage.TaskUpdateConfiguration;
0
if ( ( children != null ) && ( children.length > 0 ) ) for ( int i = 0; result && ( i < children.length ); ++i ) if ( children[i] instanceof SimpleNode ) result = ( (SimpleNode) children[i] ).isConstant( context ); throw new RuntimeException( "unknown operator for " + OgnlParserTreeConstants.jjtNodeName[id] ); ( parent == null || NumericExpression.class.isAssignableFrom( parent.getClass() ) ) ? "" : "(" ); if ( ( children != null ) && ( children.length > 0 ) ) for ( int i = 0; i < children.length; ++i ) String value = children[i].toGetSourceString( context, target ); if ( ( ASTProperty.class.isInstance( children[i] ) || ASTMethod.class.isInstance( children[i] ) || ASTSequence.class.isInstance( children[i] ) || ASTChain.class.isInstance( children[i] ) ) if ( ASTMethod.class.isInstance( children[i] ) ) cast + ExpressionCompiler.getRootExpression( children[i], context.getRoot(), context ) + pre if ( parent != null && !NumericExpression.class.isAssignableFrom( parent.getClass() ) ) String result = ( parent == null ) ? "" : "("; if ( ( children != null ) && ( children.length > 0 ) ) for ( int i = 0; i < children.length; ++i ) result += children[i].toSetSourceString( context, target ); if ( parent != null )
0
public RequestStatus deleteResources(Request request, Predicate predicate)
0
package org.apache.accumulo.monitor.rest.api.tserver; import org.apache.accumulo.monitor.rest.api.table.CompactionsList; import org.apache.accumulo.monitor.rest.api.table.CompactionsTypes; import org.apache.accumulo.monitor.rest.api.trace.RecoveryStatusInformation; /** * * Generates tserver information * * @since 2.0.0 * */ // Variable names become JSON keys /** * Generate tserver information from thrift status * * @param thriftStatus * Thrift status to obtain information */ /** * Generate tserver information from thrift status and table summary * * @param thriftStatus * Thrift status to obtain information * @param summary * Table info summary */
0
kerberosHelper.deleteIdentities(cluster, singletonList(new Component(HOST, OOZIE, OOZIE_SERVER, -1l)), newHashSet("/OOZIE/OOZIE_SERVER/oozie_server1", "/OOZIE/OOZIE_SERVER/oozie_server2")); kerberosHelper.deleteIdentities(cluster, singletonList(new Component(HOST, OOZIE, OOZIE_SERVER, -1l)), newHashSet("/OOZIE/OOZIE_SERVER/oozie_server1")); kerberosHelper.deleteIdentities(cluster, singletonList(new Component(HOST, YARN, RESOURCE_MANAGER, -1l)), newHashSet("/YARN/RESOURCE_MANAGER/rm_unique")); return newArrayList(new Component(HOST, HDFS, NAMENODE, 0l), new Component(HOST, HDFS, DATANODE, 0l)); kerberosIdentityCleaner.componentRemoved(new ServiceComponentUninstalledEvent(CLUSTER_ID, "any", "any", service, component, host, false, -1l));
0
ElementByteSizeObserver observer) throws Exception { InstantCoder.of().registerByteSizeObserver(value.getTimestamp(), observer); windowsCoder.registerByteSizeObserver(value.getWindows(), observer); PaneInfoCoder.INSTANCE.registerByteSizeObserver(value.getPane(), observer); valueCoder.registerByteSizeObserver(value.getValue(), observer); WindowedValue<T> value, ElementByteSizeObserver observer) valueCoder.registerByteSizeObserver(value.getValue(), observer);
0
import org.apache.beam.examples.complete.TfIdf; import org.apache.beam.sdk.Pipeline; import org.apache.beam.sdk.coders.StringDelegateCoder; import org.apache.beam.sdk.io.TextIO; import org.apache.beam.sdk.transforms.Create; import org.apache.beam.sdk.transforms.Keys; import org.apache.beam.sdk.transforms.RemoveDuplicates; import org.apache.beam.sdk.values.KV; import org.apache.beam.sdk.values.PCollection;
0
public CliCommand parse(String[] cmdArgs) throws CliParseException { try { cl = parser.parse(options, cmdArgs); } catch (ParseException ex) { throw new CliParseException(ex); } throw new CliParseException(getUsageStr()); public boolean exec() throws CliException { } catch (KeeperException|InterruptedException ex) { throw new CliWrapperException(ex);
0
public RsaKeyValueSecurityToken(RSAKeyValueType rsaKeyValueType, SecurityContext securityContext, super(securityContext, null, keyIdentifierType);
0
Copyright 2001 The Apache Software Foundation Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License. */
0
public LogicalRequest getRequest(long requestId) {
0
/** Utility class to contain implementations of SQL integer type conversions. */
0
return Arrays.equals(c.iterators, iterators);
0
import org.apache.hc.core5.http2.impl.Http2Processors;
0
@Override @Override @Override
0
import org.apache.accumulo.core.util.RootTable; String zRootLocPath = ZooUtil.getRoot(this) + RootTable.ZROOT_TABLET_LOCATION;
0
* @version $Revision: 1.6 $ $Date: 2004/04/09 09:43:09 $ protected static final Predicate truePredicate = PredicateUtils.truePredicate(); protected static final Predicate testPredicate = new Predicate() { public boolean evaluate(Object o) { return (o instanceof String); } }; //----------------------------------------------------------------------- //----------------------------------------------------------------------- public String getCompatibilityVersion() { return "3.1"; } // public void testCreate() throws Exception { // resetEmpty(); // writeExternalFormToDisk( // (java.io.Serializable) map, // "D:/dev/collections/data/test/PredicatedMap.emptyCollection.version3.1.obj"); // resetFull(); // writeExternalFormToDisk( // (java.io.Serializable) map, // "D:/dev/collections/data/test/PredicatedMap.fullCollection.version3.1.obj"); // }
0
expected.getHost() + Character.toString(HostPatternsHolder.WILDCARD_PATTERN), getClass().getSimpleName() + Character.toString(HostPatternsHolder.WILDCARD_PATTERN),
0
import org.apache.cocoon.ajax.AjaxHelper; import org.apache.cocoon.environment.ObjectModelHelper; import org.apache.cocoon.portal.PortalManager; import org.apache.cocoon.xml.AttributesImpl; // if ajax is used and the current request is not an ajax request, we just send some javascript stuff back if ( config.useAjax && !AjaxHelper.isAjaxRequest(ObjectModelHelper.getRequest(rendererContext.getPortalService().getProcessInfoProvider().getObjectModel()))) { final String uri = rendererContext.getPortalService().getLinkService().getRefreshLinkURI(); final char separator = (uri.indexOf('?') == -1 ? '?' : '&'); final StringBuffer buffer = new StringBuffer("cocoon.portal.process(\""); buffer.append(uri); buffer.append(separator); buffer.append(PortalManager.PROPERTY_RENDER_COPLET); buffer.append('='); buffer.append(cid.getId()); buffer.append("\");"); final AttributesImpl a = new AttributesImpl(); a.addCDATAAttribute("type", "text/javascript"); XMLUtils.createElement(handler, "script", a, buffer.toString());
0
private int count; private HashMap<Long,QuorumServer> peers; private ArrayList<FLERestartThread> restartThreads; private File tmpdir[]; private int port[]; private Semaphore finish; long leader;
0
loadFromDefaultIfNotDefined(defaultProperties, Constants.FRAMEWORK_SYSTEMPACKAGES);
0
super(Resource.Type.OperatingSystem, propertyIds, keyPropertyIds, managementController);
0
if (locator == null) { throw new ConfigurationException("Load operation not properly " + "initialized! Do not call read(InputStream) directly," + " but use a FileHandler to load a configuration."); }
0
.maxWait(walFailureRetryMax, TimeUnit.MILLISECONDS).backOffFactor(1.5) .logInterval(3, TimeUnit.MINUTES).createFactory(); .maxWait(walFailureRetryMax, TimeUnit.MILLISECONDS).backOffFactor(1.5) .logInterval(3, TimeUnit.MINUTES).createFactory();
0
Utils.checkTableDoesNotExist(instance, tableInfo.tableName, tableInfo.tableId, TableOperation.CREATE); TableManager.getInstance().addTable(tableInfo.tableId, tableInfo.namespaceId, tableInfo.tableName, NodeExistsPolicy.OVERWRITE);
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ * Tests are extended by users to perform actions on accumulo and are a node of the graph @Override public String toString() { return getClass().getName(); }
0
public static void main(String[] args)
0
if (!file.delete()) { throw new FileUploadException( "Cannot write uploaded file to disk!"); }
0
return new EnumElementValue(super.getElementValueType(), typeIdx, valueIdx, getConstantPool().getConstantPool()); ConstantUtf8 cu8 = (ConstantUtf8) getConstantPool().getConstant(valueIdx); return ((ConstantUtf8) getConstantPool().getConstant(typeIdx)) return ((ConstantUtf8) getConstantPool().getConstant(valueIdx)).getBytes();
0
import com.google.common.base.Optional; import org.apache.ambari.view.commons.hdfs.ViewPropertyHelper; import java.io.FileNotFoundException; import java.io.IOException; import java.util.Map; public static final String VIEW_CONF_KEYVALUES = "view.conf.keyvalues"; Optional<Map<String, String>> props = ViewPropertyHelper.getViewConfigs(viewContext, VIEW_CONF_KEYVALUES); HdfsApi api; if(props.isPresent()){ api = HdfsUtil.connectToHDFSApi(viewContext, props.get()); }else{ api = HdfsUtil.connectToHDFSApi(viewContext); } return api;
0
public void addUpdated(String internalGuid, AtlasEntity entity, AtlasEntityType type, AtlasVertex atlasVertex) { if (!StringUtils.equals(internalGuid, entity.getGuid())) { guidAssignments.put(internalGuid, entity.getGuid()); entityVsVertex.put(internalGuid, atlasVertex); }
0
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jxpath/src/java/org/apache/commons/jxpath/ri/model/beans/Attic/DynamicPointer.java,v 1.1 2002/04/21 21:52:33 dmitri Exp $ * $Revision: 1.1 $ * $Date: 2002/04/21 21:52:33 $ package org.apache.commons.jxpath.ri.model.beans; import org.apache.commons.jxpath.ri.*; import org.apache.commons.jxpath.ri.model.*; import org.apache.commons.jxpath.ri.model.NodePointer; import org.apache.commons.jxpath.util.*; * @version $Revision: 1.1 $ $Date: 2002/04/21 21:52:33 $ public PropertyPointer getPropertyPointer(){ return new DynamicPropertyPointer(this, handler); } return ValueUtils.getLength(getBaseValue());
0
package org.apache.hc.core5.http.io.entity;
1
import org.apache.http.mockup.SimpleHttpRequestHandlerResolver; import org.apache.http.mockup.TestHttpSSLClient; import org.apache.http.mockup.TestHttpSSLServer;
0
import static java.nio.charset.StandardCharsets.UTF_8; byte[] rowBytes = "row".getBytes(UTF_8); byte[] familyBytes = "family".getBytes(UTF_8); byte[] qualifierBytes = "qualifier".getBytes(UTF_8); byte[] visibilityBytes = "visibility".getBytes(UTF_8);
0
rep = ui.interactive(dest, name, instruction, language_tag, prompt, echo);
0
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.commons.collections4; import java.util.Iterator; /** * Defines an iterator that can be reset back to an initial state. * <p> * This interface allows an iterator to be repeatedly reused. * * @param <E> the type to iterate over * @since 3.0 * @version $Id$ */ public interface ResettableIterator<E> extends Iterator<E> { /** * Resets the iterator back to the position at which the iterator * was created. */ public void reset(); }
1
import org.apache.aurora.scheduler.events.PubsubEvent.SchedulerActive; * Notifies the cron job manager that the scheduler is active, and job configurations are ready to * @param schedulerActive Event. public void schedulerActive(SchedulerActive schedulerActive) {
0
log.debug("Removing WAL from candidate deletion as it is still needed for replication: {}", fullPath);
0
import org.apache.commons.jexl.parser.ParseException; //java.util.logging.Logger.getLogger(JexlEngine.class.getName()).setLevel(java.util.logging.Level.SEVERE); // JEXL-90: ';' is necessary between expressions public void test90() throws Exception { JexlContext ctxt = JexlHelper.createContext(); JexlEngine jexl = new JexlEngine(); jexl.setSilent(false); jexl.setLenient(false); String[] exprs = { "a=3 b=4", "while(a) while(a)", "1 2", "if (true) 2; 3 {}" }; for(int s = 0; s < exprs.length; ++s) { boolean fail = true; try { Script e = jexl.createScript(exprs[s]); } catch(ParseException xany) { // expected to fail in parse fail = false; } if (fail) { fail(exprs[s] + ": Should have failed in parse"); } } }
0
* Primitive bounds */ protected Rectangle2D primitiveBounds; /** if(primitiveBounds == null){ if(shapePainter == null) return null; primitiveBounds = shapePainter.getPaintedArea(shape).getBounds2D(); } return primitiveBounds;
0
* Bridge class for the &lt;missing-glyph&gt; element.
0
"dataflow.gcr.io/v1beta3/beam-java-batch:beam-master-20161024"; "dataflow.gcr.io/v1beta3/beam-java-streaming:beam-master-20161024";
0
* <b><i>For internal use only; no backwards-compatibility guarantees.</i></b> * * <p>Defines reflection-based utilities for analyzing {@link org.apache.beam.sdk.transforms.DoFn}'s
0
private static final int INITIAL_CACHE_CAPACITY = (int) (MAX_CACHE_ENTRIES / 0.75); private static final HashMap<String, ConstantUtf8> CACHE = new LinkedHashMap<String, ConstantUtf8>( INITIAL_CACHE_CAPACITY, 0.75f, true) { return size() > MAX_CACHE_ENTRIES; private static final int MAX_CACHED_SIZE = Integer.getInteger("bcel.maxcached.size", 200).intValue(); return new ConstantUtf8(s); hits++; return result; }
0
* Copyright 2001-2005 The Apache Software Foundation
0
context.setParent(parentContext);
0
copy.cloneInterpolator(this);
0
package org.apache.beam.examples; import org.apache.beam.sdk.Pipeline; import org.apache.beam.sdk.io.TextIO; import org.apache.beam.sdk.options.DataflowPipelineOptions; import org.apache.beam.sdk.options.PipelineOptionsFactory; import org.apache.beam.sdk.runners.BlockingDataflowPipelineRunner; import org.apache.beam.sdk.transforms.Count; import org.apache.beam.sdk.transforms.Filter; import org.apache.beam.sdk.transforms.FlatMapElements; import org.apache.beam.sdk.transforms.MapElements; import org.apache.beam.sdk.values.KV; import org.apache.beam.sdk.values.TypeDescriptor;
0
private long count; * <p> * <strong>WARNING</strong> This method will return an * incorrect count for files over 2GB - use * <code>getByteCount()</code> instead. * * @deprecated use <code>getByteCount()</code> - see issue IO-84 return (int)getByteCount(); * <p> * <strong>WARNING</strong> This method will return an * incorrect count for files over 2GB - use * <code>resetByteCount()</code> instead. * @deprecated use <code>resetByteCount()</code> - see issue IO-84 return (int)resetByteCount(); } /** * The number of bytes that have passed through this stream. * <p> * <strong>N.B.</strong> This method was introduced as an * alternative for the <code>getCount()</code> method * because that method returns an integer which will result * in incorrect count for files over 2GB being returned. * * @return the number of bytes accumulated */ public long getByteCount() { return this.count; } /** * Set the count back to 0. * <p> * <strong>N.B.</strong> This method was introduced as an * alternative for the <code>resetCount()</code> method * because that method returns an integer which will result * in incorrect count for files over 2GB being returned. * * @return the count previous to resetting. */ public synchronized long resetByteCount() { long tmp = this.count;
0
* Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at
0
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jxpath/src/java/org/apache/commons/jxpath/ri/axes/NamespaceContext.java,v 1.4 2002/04/24 04:05:39 dmitri Exp $ * $Revision: 1.4 $ * $Date: 2002/04/24 04:05:39 $ import org.apache.commons.jxpath.ri.QName; import org.apache.commons.jxpath.ri.compiler.NodeNameTest; import org.apache.commons.jxpath.ri.compiler.NodeTest; import org.apache.commons.jxpath.ri.model.NodeIterator; import org.apache.commons.jxpath.ri.model.NodePointer; * @version $Revision: 1.4 $ $Date: 2002/04/24 04:05:39 $
0