Diff
stringlengths 5
2k
| FaultInducingLabel
int64 0
1
|
---|---|
import org.apache.beam.sdk.transforms.windowing.TimestampCombiner;
TimestampCombiner timestampCombiner = input.getWindowingStrategy().getTimestampCombiner();
.map(new KeyedByTimestamp<K, V>(timestampCombiner), "keyed_by_timestamp")
.fold(new Merge<>(windowFn, timestampCombiner), "merge")
private final TimestampCombiner timestampCombiner;
public KeyedByTimestamp(TimestampCombiner timestampCombiner) {
this.timestampCombiner = timestampCombiner;
Instant timestamp = timestampCombiner.assign(
Iterables.getOnlyElement(wv.getWindows()), wv.getTimestamp());
private final TimestampCombiner timestampCombiner;
TimestampCombiner timestampCombiner) {
this.timestampCombiner = timestampCombiner;
Instant timestamp = timestampCombiner.combine(t1, t2); | 0 |
case 2:
break;
case 3:
buf[pos++] = (byte) ((x >> 16) & MASK_8BITS);
buf[pos++] = (byte) ((x >> 8) & MASK_8BITS);
break;
// WE'RE DONE!!!!
eof = true;
return; | 0 |
public <R, P> R accept( NodeVisitor<? extends R, ? super P> visitor, P data )
throws OgnlException | 0 |
/**
* Constructs a new provider.
*/ | 0 |
import com.fasterxml.jackson.annotation.JsonAutoDetect;
import com.fasterxml.jackson.annotation.JsonIgnoreProperties;
import com.fasterxml.jackson.databind.annotation.JsonSerialize;
import static com.fasterxml.jackson.annotation.JsonAutoDetect.Visibility.NONE;
import static com.fasterxml.jackson.annotation.JsonAutoDetect.Visibility.PUBLIC_ONLY; | 0 |
} catch (IllegalArgumentException e) {
} catch (IllegalArgumentException e) { | 0 |
// TODO: implements CacheableProcessingComponent { | 0 |
public void accept( final Visitor v ) { | 0 |
import org.apache.commons.jelly.JellyTagException;
public void doTag(XMLOutput xmlOutput) throws JellyTagException {
throw new JellyTagException( "<jellyResourceHandler> tag must be enclosed inside a <httpContext> tag" ); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jelly/src/java/org/apache/commons/jelly/parser/XMLParser.java,v 1.45 2003/01/24 10:04:33 morgand Exp $
* $Revision: 1.45 $
* $Date: 2003/01/24 10:04:33 $
* $Id: XMLParser.java,v 1.45 2003/01/24 10:04:33 morgand Exp $
import org.apache.commons.jelly.JellyException;
* @version $Revision: 1.45 $
} catch (Exception e) {
protected void addTextScript(String text) throws JellyException {
String attributeValue) { | 0 |
if (o instanceof Key)
return this.equals((Key) o, PartialKey.ROW_COLFAM_COLQUAL_COLVIS_TIME_DEL);
if (len == 0)
return EMPTY_BYTES;
if (!copyData && ba.length == len && off == 0)
return ba;
if (result != 0 || part.equals(PartialKey.ROW))
return result;
if (result != 0 || part.equals(PartialKey.ROW_COLFAM))
return result;
if (result != 0 || part.equals(PartialKey.ROW_COLFAM_COLQUAL))
return result;
if (result != 0 || part.equals(PartialKey.ROW_COLFAM_COLQUAL_COLVIS))
return result;
if (timestamp < other.timestamp)
result = 1;
else if (timestamp > other.timestamp)
result = -1;
else
result = 0;
if (result != 0 || part.equals(PartialKey.ROW_COLFAM_COLQUAL_COLVIS_TIME))
return result;
if (deleted)
result = other.deleted ? 0 : -1;
else
result = other.deleted ? 1 : 0;
if (c >= 32 && c <= 126)
sb.append((char) c);
else
sb.append("%" + String.format("%02x;", c));
if (a1 == a2)
return true;
if (last != a2.length)
return false;
if (last == 0)
return true;
if (a1[i] != a2[i])
return false;
if (param.size() > 0)
tkvl.set(0, new TKeyValue(param.get(0).key.toThrift(), ByteBuffer.wrap(param.get(0).value)));
if (newKey == null)
newKey = key.toThrift();
if (newKey == null)
newKey = key.toThrift();
if (newKey == null)
newKey = key.toThrift();
if (newKey == null)
newKey = key.toThrift(); | 1 |
* @version CVS $Id: SlideRepositoryImpl.java,v 1.7 2004/04/13 15:16:37 unico Exp $ | 0 |
AccumuloClient client = getAccumuloClient();
ClientInfo info = client.info();
String path = ZooUtil.getRoot(client.getInstanceID()) + Constants.ZGC_LOCK; | 0 |
import static com.google.common.util.concurrent.Uninterruptibles.sleepUninterruptibly;
private String tableId;
public Writer(ClientContext context, String tableId) {
checkArgument(tableId != null, "tableId is null");
this.tableId = tableId;
TabletLocation tabLoc = TabletLocator.getLocator(context, tableId).locateTablet(context, new Text(m.getRow()), false, true);
TabletLocator.getLocator(context, tableId).invalidateCache(tabLoc.tablet_extent);
TabletLocator.getLocator(context, tableId).invalidateCache(tabLoc.tablet_extent);
TabletLocator.getLocator(context, tableId).invalidateCache(tabLoc.tablet_extent); | 0 |
import org.apache.sshd.util.test.NoIoTestCase;
import org.junit.experimental.categories.Category;
@Category({ NoIoTestCase.class })
Path idFile = dir.resolve(getCurrentTestName() + ".pem");
KeyPair identity = Utils.getFirstKeyPair(createTestHostKeyProvider());
AtomicInteger reloadCount = new AtomicInteger(0); | 0 |
* Copyright 2001-2006 The Apache Software Foundation
* @throws ValidatorException If an error occurs during validation. | 0 |
/**
* @see org.apache.cocoon.sitemap.SitemapExecutor#enteringPipeline(org.apache.cocoon.sitemap.ExecutionContext, java.util.Map, org.apache.cocoon.sitemap.SitemapExecutor.PipelineComponentDescription)
*/
public PipelineComponentDescription enteringPipeline(ExecutionContext context, Map objectModel, PipelineComponentDescription desc) {
return desc;
}
/**
* @see org.apache.cocoon.sitemap.SitemapExecutor#notifyPipelineProcessed(org.apache.cocoon.sitemap.ExecutionContext, java.util.Map)
*/
public void notifyPipelineProcessed(ExecutionContext context, Map objectModel) {
// nothing to do
}
| 0 |
import org.apache.hc.client5.http.sync.methods.HttpExecutionAware;
import org.apache.hc.client5.http.impl.sync.RoutedHttpRequest; | 0 |
@Override | 0 |
package org.apache.beam.sdk.extensions.euphoria.core.client.operator.base;
protected final Dataset<OutputT> createOutput(
final Dataset<InputT> input, Set<OutputHint> outputHints) { | 0 |
/** The default profile name. */
protected String defaultProfileName;
// FIXME - We should use a better default than 'portal'
this.defaultProfileName = this.portalService.getConfiguration("default-profile-name", "portal");
* @see org.apache.cocoon.portal.services.UserService#getDefaultProfileName()
public String getDefaultProfileName() {
String key = this.getUser().getDefaultProfileName();
return this.defaultProfileName; | 0 |
import org.apache.hadoop.metadata.MetadataException;
protected void store(StructInstance instance, int colPos, int pos) throws RepositoryException {
StructInstance s = instance.structs[colPos];
for(Map.Entry<AttributeInfo, IAttributeStore> e : attrStores.entrySet()) {
IAttributeStore attributeStore = e.getValue();
attributeStore.store(pos, structType, s);
}
protected void load(StructInstance instance, int colPos, int pos) throws RepositoryException {
for(Map.Entry<AttributeInfo, IAttributeStore> e : attrStores.entrySet()) {
IAttributeStore attributeStore = e.getValue();
attributeStore.load(pos, structType, instance);
protected void store(StructInstance instance, int colPos, String attrName, Map<String, Object> m) {
m.put(attrName, instance.structs[colPos]);
}
protected void load(StructInstance instance, int colPos, Object val) {
instance.structs[colPos] = (StructInstance) val;
for(Map.Entry<AttributeInfo, IAttributeStore> e : attrStores.entrySet()) {
IAttributeStore attributeStore = e.getValue();
attributeStore.ensureCapacity(pos);
}
nullList.ensureCapacity(pos);
| 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.felix.ipojo.runtime.core.test.services;
/**
* A service providing a listener.
* USed to reproduce the leak bug (FELIX-4247 Memory leak with ServiceUsage and inner class (Listener style))
*/
public interface LeakingService {
Listener getListener();
String executeListener();
} | 0 |
Element group = domFactory.createElement(SVG_G_TAG);
Element testGroup = domFactory.createElement(SVG_G_TAG); | 0 |
import cz.seznam.euphoria.core.client.dataset.windowing.Batch;
keyExtractor, valueExtractor, Batch.get(), this) | 0 |
import static org.hamcrest.core.Is.isA;
import org.apache.beam.runners.spark.translation.streaming.utils.SparkTestPipelineOptions;
import org.apache.beam.sdk.transforms.DoFn;
import org.junit.rules.ExpectedException;
private static class UserException extends RuntimeException {
public final transient SparkTestPipelineOptions pipelineOptions = new SparkTestPipelineOptions();
@Rule
public final transient ExpectedException expectedException = ExpectedException.none();
p.apply(Create.of("a")).apply(ParDo.of(new DoFn<String, String>() {
@ProcessElement
expectedException.expectCause(isA(UserException.class));
p.run(); | 0 |
timerInternals.cleanupPendingTimer(timer.getNamespace());
timerInternals.cleanupPendingTimer(timer.getNamespace());
final MapState<String, TimerData> pendingTimersById; | 0 |
((SecurityManager) sm).checkPermission(
new AdminPermission(bundle, AdminPermission.EXTENSIONLIFECYCLE));
if (!((BundleProtectionDomain) bundle.getProtectionDomain()).impliesDirect(new AllPermission()))
{
throw new SecurityException("Extension Bundles must have AllPermission");
} | 0 |
import org.apache.ambari.server.controller.internal.AlertNoticeResourceProvider;
AlertNoticeResourceProvider.init(injector); | 0 |
* Copyright (c) 2002, 2003 The Apache Software Foundation. All rights
* The separator character used in file paths.
* The separator used in file paths. | 0 |
private Set<ServiceResponse> getServices(ServiceRequest request) | 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 | 1 |
public Password password = new Password("secret"); | 0 |
import org.apache.felix.sigil.common.model.IModelElement;
import org.apache.felix.sigil.common.repository.IResolution;
import org.apache.felix.sigil.common.repository.ResolutionException; | 0 |
import com.google.cloud.dataflow.sdk.util.common.worker.ElementCounter;
receiver = new OutputReceiver();
ElementCounter outputCounter = new DataflowOutputCounter(outputName, addCounterMutator);
receiver.addOutputCounter(outputCounter); | 0 |
* @version $Revision$ $Date$ | 0 |
RootedFileSystem rootedFs = null;
String scheme = uri.getScheme();
String expected = getScheme();
public AsynchronousFileChannel newAsynchronousFileChannel(Path path, Set<? extends OpenOption> options,
ExecutorService executor, FileAttribute<?>... attrs) throws IOException {
for (Map.Entry<Path, RootedFileSystem> fse : fileSystems.entrySet()) {
private static Path root(FileSystem fs, Path nat) {
+ " but rather a " + path.getClass().getSimpleName()); | 1 |
import com.twitter.mesos.gen.storage.migration.StorageMigrationPath;
import com.twitter.mesos.gen.storage.migration.StorageMigrationResult;
* {@link com.twitter.mesos.gen.storage.migration.StorageMigrationStatus#NO_MIGRATION_NEEDED}. | 0 |
* <p>
* The lookup order is:
* Windows Notes:<br> | 0 |
* @version CVS $Id: XPathSourceInspector.java,v 1.2 2003/03/16 17:49:07 vgritsenko Exp $ | 0 |
new AutoValue_XmlIO_MappingConfiguration.Builder<T>().setCharset(
StandardCharsets.UTF_8.name()).build())
new AutoValue_XmlIO_MappingConfiguration.Builder<T>().setCharset(
StandardCharsets.UTF_8.name()).build())
return new AutoValue_XmlIO_Write.Builder<T>().setCharset(StandardCharsets.UTF_8.name()).build();
outputStream.write(("<" + getRootElement() + ">\n").getBytes(Charset.forName(getCharset())));
outputStream.write(("\n</" + getRootElement() + ">").getBytes(Charset.forName(getCharset()))); | 0 |
// noop.
/**
* Returns {@code 0}.
*/
/**
* Noop.
*/
// noop.
/**
* Noop.
*/
@SuppressWarnings("sync-override")
// noop.
/**
* Returns {@code true}.
*/
/**
* Returns {@code -1}.
*/
/**
* Returns {@code -1}.
*/
/**
* Returns {@code -1}.
*/
/**
* Noop.
*/
@SuppressWarnings("sync-override")
// noop
/**
* Returns {@code 0}.
*/ | 0 |
try (SeekableByteChannel channel = accessor.openFile(
session, this, null, file, null, Collections.emptySet())) {
accessor.closeFile(session, this, null, file, null, channel, Collections.emptySet());
try (SeekableByteChannel channel = accessor.openFile(
session, this, null, path, null, Collections.emptySet())) {
accessor.closeFile(session, this, null, path, null, channel, Collections.emptySet());
ServerSession session = getServerSession();
Set<StandardOpenOption> openOptions = EnumSet.of(StandardOpenOption.WRITE);
accessor.openFile(session, this, null, file, null, openOptions)) {
accessor.closeFile(session, this, null, file, null, channel, openOptions); | 0 |
public void copy(Iterable<String> srcFilenames, Iterable<String> destFilenames)
throws IOException { | 0 |
private KV<String, org.apache.beam.runners.core.construction.Timer<byte[]>> timerBytes(
key, | 0 |
final String name = param.getName();
final boolean noQuotes = ("nc".equals(name) || "qop".equals(name)
|| "algorithm".equals(name));
final StringBuilder builder = new StringBuilder(); | 0 |
log.error("Unable to delete {}", outputFile);
log.error(e.getMessage(), e);
log.error(e.getMessage(), e);
log.error("Unable to delete {}", outputFile);
log.warn(e.getMessage(), e);
log.warn(exception.getMessage(), exception);
log.error(e.getMessage(), e);
log.warn("Failed to delete Canceled compaction output file {}", outputFile, e); | 0 |
import org.eclipse.persistence.internal.databaseaccess.FieldTypeDefinition;
executeDDLFixes();
private void executeDDLFixes() throws AmbariException, SQLException {
//Fix latest_text column type to match for all DBMS
Configuration.DatabaseType databaseType = configuration.getDatabaseType();
if (Configuration.DatabaseType.MYSQL == databaseType) {
dbAccessor.alterColumn("alert_current", new DBColumnInfo("latest_text", new FieldTypeDefinition("TEXT"), null));
} else {
dbAccessor.alterColumn("alert_current", new DBColumnInfo("latest_text", Character[].class, null));
}
}
columns.add(new DBColumnInfo("scope", String.class, 255, null, false)); | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jelly/src/java/org/apache/commons/jelly/TagLibrary.java,v 1.20 2003/01/24 05:26:13 morgand Exp $
* $Revision: 1.20 $
* $Date: 2003/01/24 05:26:13 $
* $Id: TagLibrary.java,v 1.20 2003/01/24 05:26:13 morgand Exp $
* @version $Revision: 1.20 $
throws JellyException {
try {
return (Tag) type.newInstance();
} catch (InstantiationException e) {
throw new JellyException(e.toString());
} catch (IllegalAccessException e) {
throw new JellyException(e.toString());
} | 0 |
return getQuotaInfo(role, Optional.absent(), storeProvider);
getQuotaInfo(cronConfig.getKey().getRole(), Optional.absent(), storeProvider);
: ImmutableSet.of()); | 0 |
import com.twitter.aurora.scheduler.storage.entities.IConstraint;
import com.twitter.aurora.scheduler.storage.entities.IScheduledTask;
import com.twitter.aurora.scheduler.storage.entities.ITaskConfig;
private interface FilterRule extends Function<ITaskConfig, Iterable<Veto>> { }
@Override public final Iterable<Veto> apply(ITaskConfig task) {
abstract Optional<Veto> doApply(ITaskConfig task);
@Override public Optional<Veto> doApply(ITaskConfig task) {
@Override public Optional<Veto> doApply(ITaskConfig task) {
@Override public Optional<Veto> doApply(ITaskConfig task) {
@Override public Optional<Veto> doApply(ITaskConfig task) {
private static boolean isValueConstraint(IConstraint constraint) {
return constraint.getConstraint().getSetField() == TaskConstraint._Fields.VALUE;
private static final Ordering<IConstraint> VALUES_FIRST = Ordering.from(
new Comparator<IConstraint>() {
@Override public int compare(IConstraint a, IConstraint b) {
@Override public Iterable<Veto> apply(final ITaskConfig task) {
Supplier<Collection<IScheduledTask>> activeTasksSupplier =
Suppliers.memoize(new Supplier<Collection<IScheduledTask>>() {
@Override public Collection<IScheduledTask> get() {
Query.jobScoped(Tasks.INFO_TO_JOB_KEY.apply(task).newBuilder())
for (IConstraint constraint : VALUES_FIRST.sortedCopy(task.getConstraints())) {
private Set<Veto> getResourceVetoes(Resources offer, ITaskConfig task) {
public Set<Veto> filter(Resources offer, String slaveHost, ITaskConfig task, String taskId) { | 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. | 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.atlas.sqoop.model;
/**
* Hive Data Types for model and bridge.
*/
public enum SqoopDataTypes {
// Classes
SQOOP_DBDATASTORE,
SQOOP_PROCESS,
;
public String getName() {
return name().toLowerCase();
}
} | 0 |
verify("mntr", "num_alive_connections");
verify("stat", "Connections");
verify("srvr", "Connections");
Assert.assertTrue(Pattern.matches("^Connections: \\d+$", line));
line = in.readLine(); | 0 |
import org.apache.ambari.logsearch.common.Marker;
@Marker
public interface TopFieldAuditLogRequest extends FieldAuditLogRequest, TopParamDefinition, UserParamDefinition { | 0 |
package org.w3c.dom.svg;
import org.w3c.dom.DOMException;
public interface SVGRect {
public float getX( );
public void setX( float x )
throws DOMException;
public float getY( );
public void setY( float y )
throws DOMException;
public float getWidth( );
public void setWidth( float width )
throws DOMException;
public float getHeight( );
public void setHeight( float height )
throws DOMException;
} | 1 |
LOG.debug("{} cookie has been found and is being processed", cookieName); | 0 |
import org.apache.beam.vendor.guava.v20_0.com.google.common.base.Joiner; | 0 |
package org.apache.accumulo.core.clientImpl.mapreduce.lib; | 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.
*/
* Information about the current merge/rangeDelete.
*
MERGE, DELETE,
public MergeInfo() {}
if (!extent.getTableId().equals(range.getTableId())) return false;
if (isDelete()) return extent.getPrevEndRow() != null && extent.getPrevEndRow().equals(range.getEndRow());
else return this.range.overlaps(extent);
if (!result && needsToBeChopped(extent)) return true;
if (!state.equals(MergeState.NONE)) return "Merge " + operation.toString() + " of " + range + " State: " + state; | 0 |
import org.apache.sshd.common.util.AbstractLoggingBean;
public abstract class AbstractUserAuth extends AbstractLoggingBean implements UserAuth { | 1 |
try (CloseableHttpClient httpclient = HttpClients.createDefault()) {
try (CloseableHttpResponse response = httpclient.execute(httpget, localContext)) { | 0 |
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128);
SessionOutputBuffer outbuf = new SessionOutputBufferImpl(1024, 128); | 0 |
/**
* Copyright 2013 Apache Software Foundation | 0 |
LOG.debug("Looking for duplicate service " + service.getName()); | 0 |
* @version $Revision$ $Date$ | 0 |
import org.apache.felix.sigil.ui.eclipse.ui.wizard.project.SigilProjectWizard; | 0 |
import org.apache.hadoop.conf.Configuration;
public void configure(MiniAccumuloConfigImpl cfg, Configuration hadoopCoreSite) {
super.configure(cfg, hadoopCoreSite); | 0 |
assertEquals("Set value (bar:2)", bean.getBar(), "beta");
Method method = null;
try {
method = MethodUtils.getAccessibleMethod(PublicSubBean.class, "setFoo", String.class);
} catch (Throwable t) {
fail("getAccessibleMethod() setFoo threw " + t);
}
assertNotNull("getAccessibleMethod() setFoo is Null", method);
try {
method.invoke(bean, new Object[] {"1111"});
} catch (Throwable t) {
fail("Invoking setFoo threw " + t);
}
assertEquals("Set value (foo:3)", "1111", bean.getFoo());
try {
method = MethodUtils.getAccessibleMethod(PublicSubBean.class, "setBar", String.class);
} catch (Throwable t) {
fail("getAccessibleMethod() setBar threw " + t);
}
assertNotNull("getAccessibleMethod() setBar is Null", method);
try {
method.invoke(bean, new Object[] {"2222"});
} catch (Throwable t) {
fail("Invoking setBar threw " + t);
}
assertEquals("Set value (bar:3)", "2222", bean.getBar());
| 0 |
private HandleErrorsNode error;
void setErrorHandler(ProcessingNode node) {
this.error = (HandleErrorsNode) node;
return this.error == null;
return this.error != null && this.error.isInternal();
return this.error != null && this.error.isExternal();
} else if (error != null) {
// Invoke error handler
return prepareErrorHandler(error, ex, env, context);
// Exception was not handled by this error handler, propagate. | 0 |
public boolean isEvalChain( OgnlContext context )
throws OgnlException
{
if ( children == null )
{
return false;
}
for ( Node child : children )
{
if ( child instanceof SimpleNode )
{
if ( ( (SimpleNode) child ).isEvalChain( context ) )
{
return true;
}
}
}
return false;
}
| 0 |
import net.jcip.annotations.Immutable;
@Immutable | 0 |
HttpClientContext clientContext = HttpClientContext.adapt(context);
CookieSpec cookieSpec = clientContext.getCookieSpec();
CookieStore cookieStore = clientContext.getCookieStore();
CookieOrigin cookieOrigin = clientContext.getCookieOrigin(); | 0 |
* Get path to accumulo-site.xml
*/
String getSitePath();
/** | 0 |
Boolean authed = null;
authed = auth.auth(this, username, buffer);
if (authed == null) {
log.info(authed ? "Authentication succeeded" : "Authentication failed");
authed = false;
if (authed != null && authed) {
this.authed = true; | 0 |
import org.apache.accumulo.server.fs.FileRef;
import org.apache.accumulo.server.fs.VolumeManager;
private static final Map<FileRef,DataFileValue> EMPTY_MAP = Collections.emptyMap();
private static Map<FileRef,DataFileValue> toFileMap(FileRef mergeFile, DataFileValue dfv) {
MinorCompactor(Configuration conf, VolumeManager fs, InMemoryMap imm, FileRef mergeFile, DataFileValue dfv, FileRef outputFile, TableConfiguration acuTableConf,
getFileSystem().deleteRecursively(new Path(getOutputFile())); | 1 |
* The put method will only succeed if the key specified is the same as the | 0 |
public static List<Article> getArticleInfo(NNTPClient client, int lowArticleNumber, int highArticleNumber) | 0 |
@Override
public final String toString() { | 0 |
private static final long serialVersionUID = 1L;
| 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.
* @version $Id: BaseConfiguration.java,v 1.4 2004/02/27 17:41:35 epugh Exp $ | 0 |
Method allowClusterOperatorToManageCredentials = UpgradeCatalog240.class.getDeclaredMethod("allowClusterOperatorToManageCredentials");
.addMockedMethod(allowClusterOperatorToManageCredentials)
upgradeCatalog240.allowClusterOperatorToManageCredentials(); | 0 |
import static org.apache.atlas.TestUtilsV2.NAME; | 1 |
public interface Options extends LeaderBoard.Options { | 0 |
import org.apache.http.conn.HttpRoute;
/**
* The scheme registry.
* Instantiated in {@link #setup setup}.
*/
private static SchemeRegistry supportedSchemes;
final HttpRoute route = new HttpRoute
(target, null, proxy,
supportedSchemes.getScheme(target).isLayered());
final RoutedRequest roureq = new RoutedRequest.Impl(req, route);
new DefaultHttpClient(getParams(), ccm, supportedSchemes);
//@@@ use dedicated SchemeRegistry instance
//@@@ currently no way to pass it to TSCCM
supportedSchemes = SchemeRegistry.DEFAULT; //new SchemeRegistry();
supportedSchemes.register(new Scheme("http", sf, 80));
supportedSchemes.register(new Scheme("https", sf, 80)); | 0 |
import org.apache.beam.sdk.coders.ByteStringCoder;
import org.apache.beam.sdk.coders.IterableCoder;
import org.apache.beam.sdk.coders.KvCoder;
import org.apache.beam.sdk.coders.protobuf.ProtoCoder;
p.apply(
Create.empty(
KvCoder.of(ByteStringCoder.of(), IterableCoder.of(ProtoCoder.of(Mutation.class))))); | 0 |
* @version $Id: AbstractConfiguration.java,v 1.16 2004/06/24 14:01:03 ebourg Exp $
/** how big the initial arraylist for splitting up name value pairs */
private static final int INITIAL_LIST_SIZE = 2;
* {@inheritDoc}
return interpolateHelper(base, null);
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
Properties props = defaults == null ? new Properties() : new Properties(defaults);
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
/**
* {@inheritDoc}
*/
/**
* {@inheritDoc}
*/
/**
* {@inheritDoc}
*/
/**
* {@inheritDoc}
*/
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
* {@inheritDoc}
private List list; | 0 |
import org.apache.ambari.server.controller.internal.ViewInstanceResourceProvider;
@ApiModelProperty(name = ViewInstanceResourceProvider.VIEW_INSTANCE_INFO)
@ApiModelProperty(name = ViewInstanceResourceProvider.VIEW_NAME_PROPERTY_ID, hidden = true)
@ApiModelProperty(name = ViewInstanceResourceProvider.VERSION_PROPERTY_ID, hidden = true)
@ApiModelProperty(name = ViewInstanceResourceProvider.INSTANCE_NAME_PROPERTY_ID, hidden = true)
@ApiModelProperty(name = ViewInstanceResourceProvider.LABEL_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.DESCRIPTION_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.VISIBLE_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.ICON_PATH_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.ICON64_PATH_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.PROPERTIES_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.INSTANCE_DATA_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.CLUSTER_HANDLE_PROPERTY_ID)
@ApiModelProperty(name = ViewInstanceResourceProvider.CLUSTER_TYPE_PROPERTY_ID) | 0 |
* <p>For the Fn API, the {@link PTransformOverrideFactory} is only required to perform per key
* grouping and expansion.
* Returns a {@link PTransformOverrideFactory} that replaces a multi-output {@link ParDo} with a
* composite transform specialized for the {@link DataflowRunner}.
StatefulSingleOutputParDo(
ParDo.SingleOutput<KV<K, InputT>, OutputT> originalParDo, boolean isFnApi) {
StatefulMultiOutputParDo(
ParDo.MultiOutput<KV<K, InputT>, OutputT> originalParDo, boolean isFnApi) {
static class ExpandGbkFn<K, V> extends DoFn<KV<K, Iterable<V>>, KV<K, V>> { | 1 |
* @version CVS $Id: ValueJXPathBinding.java,v 1.11 2004/02/03 12:22:08 joerg Exp $
public void doLoad(Widget frmModel, JXPathContext jxpc) throws BindingException {
if (widget == null) {
throw new BindingException("The widget with the ID [" + this.fieldId
+ "] referenced in the binding does not exist in the form definition.");
} | 0 |
assertEquals("0+", resolveComponent(info, parentInfo).getModuleInfo().getCardinality()); | 0 |
org.osgi.framework.hooks.service.EventListenerHook.class, | 0 |
for (final String scheme : urlSchemes)
for (final String scheme : urlSchemes)
for (Object provider : providers.values())
for (FileProvider fileProvider : providers.values())
final AbstractFileProvider provider = (AbstractFileProvider) fileProvider; | 0 |
* Copyright (c) 2002 The Apache Software Foundation. All rights | 0 |
import static org.apache.accumulo.fate.util.UtilWaitThread.sleepUninterruptibly; | 0 |
log.warn("Expected Digest: " + Base64.encode(elemDig));
log.warn("Actual Digest: " + Base64.encode(calcDig)); | 0 |
* Bridge class for the <flowRoot> element.
* Constructs a new bridge for the <flowRoot> element. | 0 |
* $Header: /home/jerenkrantz/tmp/commons/commons-convert/cvs/home/cvs/jakarta-commons//jxpath/src/java/org/apache/commons/jxpath/ri/model/dom/DOMNamespaceIterator.java,v 1.2 2002/04/24 04:05:40 dmitri Exp $
* $Revision: 1.2 $
* $Date: 2002/04/24 04:05:40 $
import java.util.ArrayList;
import java.util.List;
import org.w3c.dom.Attr;
import org.w3c.dom.NamedNodeMap;
import org.w3c.dom.Node;
* @version $Revision: 1.2 $ $Date: 2002/04/24 04:05:40 $ | 0 |
* @version $Id: Action.java,v 1.4 2004/04/09 16:43:21 mpo Exp $
private final ActionDefinition definition;
protected WidgetDefinition getDefinition() {
return this.definition;
| 0 |
UserEntity userEntity = userDAO.findUserByName(userName); | 0 |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.